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 

A

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.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.
abs() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
Abs - Class in org.apache.flink.api.table.expressions
 
Abs(Expression) - Constructor for class org.apache.flink.api.table.expressions.Abs
 
abs() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
abs() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
Abs$ - Class in org.apache.flink.api.table.expressions
 
Abs$() - Constructor for class org.apache.flink.api.table.expressions.Abs$
 
AbstractAlignedProcessingTimeWindowOperator<KEY,IN,OUT,STATE,F extends Function> - Class in org.apache.flink.streaming.runtime.operators.windowing
 
AbstractAlignedProcessingTimeWindowOperator(F, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<STATE>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
 
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
 
AbstractCEPPatternOperator<IN> - Class in org.apache.flink.cep.operator
Base class for CEP pattern operator.
AbstractCEPPatternOperator(TypeSerializer<IN>, boolean) - Constructor for class org.apache.flink.cep.operator.AbstractCEPPatternOperator
 
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
 
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
 
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.runtime.state.filesystem
Base class for state that is stored in a file.
AbstractFileStateHandle(Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateHandle
Creates a new file state for the given file path.
AbstractFlinkYarnClient - Class in org.apache.flink.runtime.yarn
Abstract interface for an implementation of a Flink on YARN client to deploy.
AbstractFlinkYarnClient() - Constructor for class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
AbstractFlinkYarnCluster - Class in org.apache.flink.runtime.yarn
Abstract class for interacting with a running Flink cluster within YARN.
AbstractFlinkYarnCluster() - Constructor for class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
 
AbstractFsState<K,N,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.filesystem
Base class for partitioned ListState implementations that are backed by a regular heap hash map.
AbstractFsState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsState
 
AbstractFsState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, HashMap<N, Map<K, SV>>) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsState
 
AbstractFsStateSnapshot<K,N,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.filesystem
A snapshot of a heap key/value state stored in a file.
AbstractFsStateSnapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
Creates a new state snapshot with data in the file system.
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
 
AbstractHeapState<K,N,SV,S extends State,SD extends StateDescriptor<S,?>,Backend extends AbstractStateBackend> - Class in org.apache.flink.runtime.state
Base class for partitioned ListState implementations that are backed by a regular heap hash map.
AbstractHeapState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD) - Constructor for class org.apache.flink.runtime.state.AbstractHeapState
Creates a new empty key/value state.
AbstractHeapState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, HashMap<N, Map<K, SV>>) - Constructor for class org.apache.flink.runtime.state.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
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
 
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
 
AbstractMemState<K,N,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.memory
Base class for partitioned ListState implementations that are backed by a regular heap hash map.
AbstractMemState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD) - Constructor for class org.apache.flink.runtime.state.memory.AbstractMemState
 
AbstractMemState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, HashMap<N, Map<K, SV>>) - Constructor for class org.apache.flink.runtime.state.memory.AbstractMemState
 
AbstractMemStateSnapshot<K,N,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.memory
A snapshot of a MemValueState for a checkpoint.
AbstractMemStateSnapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
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
 
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
 
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
 
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
 
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
 
AbstractRocksDBSnapshot(File, String, URI, long, TypeSerializer<K>, TypeSerializer<N>, SD) - Constructor for class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
Creates a new snapshot from the given state parameters.
AbstractRocksDBState<K,N,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.contrib.streaming.state
Base class for State implementations that store state in a RocksDB database.
AbstractRocksDBState(TypeSerializer<K>, TypeSerializer<N>, File, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Creates a new RocksDB backed state.
AbstractRocksDBState(TypeSerializer<K>, TypeSerializer<N>, File, String, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Creates a new RocksDB backed state and restores from the given backup directory.
AbstractRocksDBState.AbstractRocksDBSnapshot<K,N,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.contrib.streaming.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>>) - 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.runtime.state
A state backend defines how state is stored and snapshotted during checkpoints.
AbstractStateBackend() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend
 
AbstractStateBackend.CheckpointStateOutputStream - Class in org.apache.flink.runtime.state
A dedicated output stream that produces a StreamStateHandle when closed.
AbstractStateBackend.CheckpointStateOutputView - Class in org.apache.flink.runtime.state
A dedicated DataOutputView stream that produces a StateHandle<DataInputView> when closed.
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
 
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
 
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
 
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(Visitor<T>) - Method in interface org.apache.flink.util.Visitable
Contains the logic to invoke the visitor and continue the traversal.
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
 
accessField(Field, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
This method is handling the IllegalAccess exceptions of Field.get()
AccumulatingKeyedTimePanes<Type,Key,Result> - Class in org.apache.flink.streaming.runtime.operators.windowing
 
AccumulatingKeyedTimePanes(KeySelector<Type, Key>, WindowFunction<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
 
AccumulatingProcessingTimeWindowOperator(WindowFunction<IN, OUT, KEY, TimeWindow>, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<IN>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator
 
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 internal and user-defined accumulators.
AccumulatorRegistry(JobID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
AccumulatorRegistry.Metric - Enum in org.apache.flink.runtime.accumulators
Flink metrics supported
AccumulatorRegistry.Reporter - Interface in org.apache.flink.runtime.accumulators
Interface for Flink's internal accumulators.
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
 
AccumulatorSnapshot - Class in org.apache.flink.runtime.accumulators
This class encapsulates a map of accumulators for a single task.
AccumulatorSnapshot(JobID, ExecutionAttemptID, Map<AccumulatorRegistry.Metric, Accumulator<?, ?>>, 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$() - Constructor for class org.apache.flink.runtime.messages.Messages.Acknowledge$
 
AcknowledgeApplicationClientRegistration$() - Constructor for class org.apache.flink.yarn.YarnMessages.AcknowledgeApplicationClientRegistration$
 
acknowledgeCheckpoint(long) - 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, StateHandle<?>) - 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 - 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) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long, SerializedValue<StateHandle<?>>, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
acknowledgeCheckpoint(long) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
acknowledgeCheckpoint(long, StateHandle<?>) - 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, SerializedValue<StateHandle<?>>, long) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
ACTION_INFO - Static variable in class org.apache.flink.client.CliFrontend
 
ACTION_RUN - Static variable in class org.apache.flink.client.CliFrontend
 
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
 
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.
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(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(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(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) - Method in interface org.apache.flink.api.common.state.MergingState
Updates the operator state accessible by MergingState.get() by adding the given value to the list of values.
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(Object) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsAccumulator
 
add(T) - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
 
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(Parameter<T>, T) - Method in class org.apache.flink.ml.common.ParameterMap
Adds a new parameter value to the ParameterMap.
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(T) - Method in class org.apache.flink.runtime.state.filesystem.FsFoldingState
 
add(V) - Method in class org.apache.flink.runtime.state.filesystem.FsListState
 
add(V) - Method in class org.apache.flink.runtime.state.filesystem.FsReducingState
 
add(T) - Method in class org.apache.flink.runtime.state.GenericFoldingState
 
add(T) - Method in class org.apache.flink.runtime.state.GenericListState
 
add(T) - Method in class org.apache.flink.runtime.state.GenericReducingState
 
add(T) - Method in class org.apache.flink.runtime.state.memory.MemFoldingState
 
add(V) - Method in class org.apache.flink.runtime.state.memory.MemListState
 
add(V) - Method in class org.apache.flink.runtime.state.memory.MemReducingState
 
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(String, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Creates a state handle and stores it in ZooKeeper with create mode CreateMode.PERSISTENT.
add(String, T, CreateMode) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Creates a state handle and stores it in ZooKeeper.
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ByteSum
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.DoubleSum
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.FloatSum
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.IntSum
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.LongSum
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ShortSum
 
add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
 
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(Void) - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
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(int, V) - Method in class org.apache.flink.types.ListValue
 
add(V) - Method in class org.apache.flink.types.ListValue
 
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
 
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.UnmodifiableConfiguration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(Configuration) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
addAll(Configuration, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
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
 
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
 
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.
addBroadcastSetForMessagingFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Adds a data set as a broadcast set to the messaging 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.
addBroadcastSetForUpdateFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Adds a data set as a broadcast set to the vertex update 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.ZooKeeperCompletedCheckpointStore
Synchronously writes the new checkpoints to ZooKeeper and asynchronously removes older ones.
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
 
addComparatorField(int, TypeComparator<?>) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
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
 
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.
addDateFormatter() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
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.
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
 
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
 
addGlobalProperties(RequestedGlobalProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
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.
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.
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
 
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.
addList(List<T>) - Method in class org.apache.flink.runtime.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
 
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
 
addObject(Object) - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.CountMinHeavyHitter
 
addObject(Object) - Method in interface org.apache.flink.contrib.operatorstatistics.heavyhitters.HeavyHitter
 
addObject(Object) - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.LossyCounting
 
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.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.
addPostParameter(String, String) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets a post parameter.
addPostParameters(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets post parameters.
addQueryParameter(String, String) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets a query parameter.
addQueryParameters(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets query parameters.
addRandomPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addRandomPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
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
 
addRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
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 - 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.instance.InstanceConnectionInfo
Returns the network address the instance's task manager binds its sockets to.
address() - Method in class org.apache.flink.runtime.messages.JobClientMessages.JobManagerLeaderAddress
 
addressLimit - Variable in class org.apache.flink.core.memory.MemorySegment
The address one byte after the last addressable byte.
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
 
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.
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.
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(StateTransition<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
 
addTimeFormatter() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
addTimestampFormatter() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
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
 
addType(int, Class<? extends Key<?>>) - Method in class org.apache.flink.optimizer.postpass.SparseKeySchema
 
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.
AdjacencyList(long, long[]) - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.AdjacencyList
 
AdjacencyList(long, long[]) - Constructor for class org.apache.flink.examples.scala.PageRankTable.AdjacencyList
 
AdjacencyList$() - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.AdjacencyList$
 
AdjacencyList$() - Constructor for class org.apache.flink.examples.scala.PageRankTable.AdjacencyList$
 
adjustGlobalPropertiesForFullParallelismChange() - Method in class org.apache.flink.optimizer.plan.Channel
 
adjustTop() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Should be called when the Object at top changes values.
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.
agg - Variable in class org.apache.flink.python.api.PythonOperationInfo.AggregationEntry
 
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(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 - Class in org.apache.flink.api.table.plan
Internal operation.
Aggregate(PlanNode, Seq<Tuple2<String, Aggregations>>) - Constructor for class org.apache.flink.api.table.plan.Aggregate
 
aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
 
aggregate(AggregationFunction.AggregationType, int) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
 
aggregate(AggregationFunction.AggregationType, int) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
 
Aggregate$ - Class in org.apache.flink.api.table.plan
 
Aggregate$() - Constructor for class org.apache.flink.api.table.plan.Aggregate$
 
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
 
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
 
aggregates - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
aggregateUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Merges all accumulator results from the tasks previously executed in the Executions.
AggregatingKeyedTimePanes<Type,Key> - Class in org.apache.flink.streaming.runtime.operators.windowing
 
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
 
AggregatingProcessingTimeWindowOperator(ReduceFunction<IN>, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<IN>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AggregatingProcessingTimeWindowOperator
 
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.api.table.expressions
 
Aggregation() - Constructor for class org.apache.flink.api.table.expressions.Aggregation
 
AggregationEntry(int, int) - Constructor for class org.apache.flink.python.api.PythonOperationInfo.AggregationEntry
 
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
 
AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
 
AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
 
AggregationFunctionFactory - Interface in org.apache.flink.api.java.aggregation
 
Aggregations - Enum in org.apache.flink.api.java.aggregation
 
aggregations() - Method in class org.apache.flink.api.table.plan.Aggregate
 
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_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.
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_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.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.ConfigConstants
Heartbeat interval of watch failure detector
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
 
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.api.table.parser.ExpressionParser$
 
alias() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
allBufferPools - Variable in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
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
 
allocatedContainersList() - Method in class org.apache.flink.yarn.YarnJobManager
 
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(int[], int) - Static method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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.
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.
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
 
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.
AMRMClientAsyncHandler() - Method in class org.apache.flink.yarn.YarnJobManager
 
AMRMClientAsyncHandler() - Constructor for class org.apache.flink.yarn.YarnJobManager.AMRMClientAsyncHandler
Heartbeats with the resource manager and informs of container updates.
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
 
analyze(A) - Method in class org.apache.flink.api.table.trees.Analyzer
 
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
 
Analyzer<A extends TreeNode<A>> - Class in org.apache.flink.api.table.trees
Base class for tree analyzers/transformers.
Analyzer() - Constructor for class org.apache.flink.api.table.trees.Analyzer
 
analyzeSingleInputUdf(SingleInputUdfOperator<?, ?, ?>, Class<?>, String, Function, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
 
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 - Class in org.apache.flink.api.table.expressions
 
And(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.And
 
And$ - Class in org.apache.flink.api.table.expressions
 
And$() - Constructor for class org.apache.flink.api.table.expressions.And$
 
AndFilterFunction<T> - Class in org.apache.flink.cep.pattern
A filter function which combines two filter functions with a logical and.
AndFilterFunction(FilterFunction<T>, FilterFunction<T>) - Constructor for class org.apache.flink.cep.pattern.AndFilterFunction
 
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
 
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
 
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 Key<?>>, 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.
ApplicationClient - Class in org.apache.flink.yarn
Actor which is responsible to repeatedly poll the Yarn cluster status from the JobManager.
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$
 
ApplicationMaster - Class in org.apache.flink.yarn
Default implementation of the ApplicationMasterBase which starts a YarnJobManager and a MemoryArchivist.
ApplicationMaster() - Constructor for class org.apache.flink.yarn.ApplicationMaster
 
ApplicationMaster$ - Class in org.apache.flink.yarn
 
ApplicationMaster$() - Constructor for class org.apache.flink.yarn.ApplicationMaster$
 
ApplicationMasterBase - Class in org.apache.flink.yarn
Base class for all application masters.
ApplicationMasterBase() - Constructor for class org.apache.flink.yarn.ApplicationMasterBase
 
ApplicationMasterBase$ - Class in org.apache.flink.yarn
 
ApplicationMasterBase$() - Constructor for class org.apache.flink.yarn.ApplicationMasterBase$
 
ApplicationMasterStatus(int, int) - Constructor for class org.apache.flink.yarn.YarnMessages.ApplicationMasterStatus
 
ApplicationMasterStatus$() - Constructor for class org.apache.flink.yarn.YarnMessages.ApplicationMasterStatus$
 
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(CompositeType<?>, CompositeType<?>, Expression) - Method in class org.apache.flink.api.table.expressions.analysis.ExtractEquiJoinFields$
 
apply(CompositeType<?>, CompositeType<?>, Expression) - Static method in class org.apache.flink.api.table.expressions.analysis.ExtractEquiJoinFields
 
apply(Expression) - Method in class org.apache.flink.api.table.expressions.analysis.GroupByAnalyzer.CheckGroupExpression
 
apply(Expression) - Method in class org.apache.flink.api.table.expressions.analysis.InsertAutoCasts
 
apply(Expression) - Method in class org.apache.flink.api.table.expressions.analysis.ResolveFieldReferences
 
apply(Expression) - Method in class org.apache.flink.api.table.expressions.analysis.TypeCheck
 
apply(Expression) - Method in class org.apache.flink.api.table.expressions.analysis.VerifyBoolean
 
apply(Expression) - Method in class org.apache.flink.api.table.expressions.analysis.VerifyNoAggregates
 
apply(Expression) - Method in class org.apache.flink.api.table.expressions.analysis.VerifyNoNestedAggregates
 
apply(Object) - Method in class org.apache.flink.api.table.expressions.Literal$
 
apply(Object) - Static method in class org.apache.flink.api.table.expressions.Literal
 
apply(Select) - Method in class org.apache.flink.api.table.plan.ExpandAggregations$
 
apply(Select) - Static method in class org.apache.flink.api.table.plan.ExpandAggregations
 
apply(A) - Method in class org.apache.flink.api.table.trees.Rule
 
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.optimization.GradientDescentL1$
 
apply() - Static method in class org.apache.flink.ml.optimization.GradientDescentL1
 
apply() - Method in class org.apache.flink.ml.optimization.GradientDescentL2$
 
apply() - Static method in class org.apache.flink.ml.optimization.GradientDescentL2
 
apply() - Method in class org.apache.flink.ml.optimization.SimpleGradientDescent$
 
apply() - Static method in class org.apache.flink.ml.optimization.SimpleGradientDescent
 
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(int) - 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(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(AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies a window function to the 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
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.datastream.AllWindowedStream
Applies the given window function to each window.
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
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
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.datastream.WindowedStream
Applies the given window function to each window.
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
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<ACC>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<ACC>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
 
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(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceIterableWindowFunction
 
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
Applies the given window function to each window.
apply(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.
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
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
Applies the given window function to each window.
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(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
Applies the given window function to each window.
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
Applies the given window function to each window.
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
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
Applies the given window function to each window.
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(KEY, W, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
apply(KEY, W, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
apply(KEY, W, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
Evaluates the window and outputs none or several elements.
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
 
applyIteratorTrueAssumption() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
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
applyWithState(I, Function2<I, Option<S>, Tuple2<O, Option<S>>>) - Method in interface org.apache.flink.streaming.api.scala.function.StatefulFunction
 
archive() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
ARCHIVE_NAME() - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Name of the archive actor
ARCHIVE_NAME() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Name of the archive actor
ArchivedJob(Option<ExecutionGraph>) - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJob
 
ArchivedJob$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJob$
 
ArchivedJobs(Iterable<ExecutionGraph>) - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs
 
ArchivedJobs$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs$
 
ArchiveExecutionGraph(JobID, ExecutionGraph) - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchiveExecutionGraph
 
ArchiveExecutionGraph$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchiveExecutionGraph$
 
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.
ARGUMENT_PYTHON_2 - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
ARGUMENT_PYTHON_3 - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
arguments - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
arity - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
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.
ArrayDescriptor(int, scala.reflect.macros.Context.universe, TypeDescriptors<C>.UDTDescriptor) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.ArrayDescriptor
 
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
 
arrayToString(Object) - Static method in class org.apache.flink.util.StringUtils
Returns a string representation of the given array.
as(Seq<Expression>) - Method in class org.apache.flink.api.scala.table.DataSetConversions
Converts the DataSet to a Table.
as(Seq<Expression>) - Method in class org.apache.flink.api.scala.table.DataStreamConversions
Converts the DataStream to a Table.
as(Symbol) - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
AS() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
as() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
AS() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
as() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
As - Class in org.apache.flink.api.table.plan
Operation that gives new names to fields.
As(PlanNode, Seq<String>) - Constructor for class org.apache.flink.api.table.plan.As
 
as(Seq<Expression>) - Method in class org.apache.flink.api.table.Table
Renames the fields of the expression result.
as(String) - Method in class org.apache.flink.api.table.Table
Renames the fields of the expression result.
As$ - Class in org.apache.flink.api.table.plan
 
As$() - Constructor for class org.apache.flink.api.table.plan.As$
 
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
 
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
A timestamp assigner and watermark generator for streams where timestamps are monotonously ascending.
AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
 
AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions
Handler that fails the program when timestamp monotony is violated.
AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions
Handler that does nothing when timestamp monotony is violated.
AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions
Handler that only logs violations of timestamp monotony, on WARN log level.
AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions
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.
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() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
The timeout for all actor ask futures
asRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a StreamRecord.
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.
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.
assignPartition(int, byte) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Assigns a partition to a bucket.
assignPartitions(List<T>, int, int) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
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
 
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
Extracts a timestamp from an element and assigns it as the internal timestamp of that element.
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 periodically creates watermarks to signal event time progress.
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.
assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
assignWindows(Object, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
assignWindows(T, long) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns a Collection of windows that should be assigned to the element.
associateWithTaskManagerAndJobManager(ActorGateway, ActorGateway) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
This associates the network environment with a TaskManager and JobManager.
asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a Watermark.
asyncException - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Errors encountered in the async producer are stored here
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
RuntimeException for wrapping exceptions that are thrown in Threads that are not the main compute Thread.
AsynchronousException(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.
AsynchronousKvStateSnapshot<K,N,S extends State,SD extends StateDescriptor<S,?>,Backend extends AbstractStateBackend> - Class in org.apache.flink.runtime.state
KvStateSnapshot that asynchronously materializes the state that it represents.
AsynchronousKvStateSnapshot() - Constructor for class org.apache.flink.runtime.state.AsynchronousKvStateSnapshot
 
AsynchronousStateHandle<T> - Class in org.apache.flink.runtime.state
StateHandle that can asynchronously materialize the state that it represents.
AsynchronousStateHandle() - Constructor for class org.apache.flink.runtime.state.AsynchronousStateHandle
 
atom() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
atom() - Static method in class org.apache.flink.api.table.parser.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
 
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
 
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
 
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
 
authenticate() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
autoAck - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
AutomaticWatermarkContext(StreamSource<?, ?>, Object, Output<StreamRecord<T>>, long) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
 
available() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
available() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
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
 
avg() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
Avg - Class in org.apache.flink.api.table.expressions
 
Avg(Expression) - Constructor for class org.apache.flink.api.table.expressions.Avg
 
AVG() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
avg() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
AVG() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
avg() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
Avg$ - Class in org.apache.flink.api.table.expressions
 
Avg$() - Constructor for class org.apache.flink.api.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
 
AvgKafkaMetricAccumulator - Class in org.apache.flink.streaming.connectors.kafka.internals.metrics
 
AvgKafkaMetricAccumulator(KafkaMetric) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.metrics.AvgKafkaMetricAccumulator
 
AvroInputFormat<E> - Class in org.apache.flink.api.java.io
 
AvroInputFormat(Path, Class<E>) - Constructor for class org.apache.flink.api.java.io.AvroInputFormat
 
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
 
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
 
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
 
awaitJobManagerGatewayAndWebPort() - Method in class org.apache.flink.runtime.webmonitor.JobManagerRetriever
Awaits the leading job manager gateway and its web monitor port.
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

back() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
BackPressureStatsTracker - Class in org.apache.flink.runtime.webmonitor
Back pressure statistics tracker.
BackPressureStatsTracker(StackTraceSampleCoordinator, int, int, FiniteDuration) - Constructor for class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Creates a back pressure statistics tracker.
backupUri - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
 
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
 
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
 
basePath - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
Store it so that we can clean up in dispose()
basePath - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Store it so that we can clean up in dispose()
BaseStatistics - Interface in org.apache.flink.api.common.io.statistics
Interface describing the basic statistics that can be obtained from the input.
BasicArrayTypeInfo<T,C> - Class in org.apache.flink.api.common.typeinfo
 
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, and Void.
BasicTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
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() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Handler for shared broadcast variables (shared between multiple Tasks)
begin(String) - Static method in class org.apache.flink.cep.pattern.Pattern
Starts a new pattern with the initial pattern operator whose name is provided.
beginIndex() - Method in class org.apache.flink.api.table.expressions.Substring
 
BEGINNING_STATE_NAME - Static variable in class org.apache.flink.cep.nfa.compiler.NFACompiler
 
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.
BinaryArithmetic - Class in org.apache.flink.api.table.expressions
 
BinaryArithmetic() - Constructor for class org.apache.flink.api.table.expressions.BinaryArithmetic
 
binaryBitwise() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
binaryBitwise() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
BinaryComparison - Class in org.apache.flink.api.table.expressions
 
BinaryComparison() - Constructor for class org.apache.flink.api.table.expressions.BinaryComparison
 
BinaryExpression - Class in org.apache.flink.api.table.expressions
 
BinaryExpression() - Constructor for class org.apache.flink.api.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
Writes a block info at the end of the blocks.
Current implementation uses only int and not long.
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.api.table.expressions
 
BinaryPredicate() - Constructor for class org.apache.flink.api.table.expressions.BinaryPredicate
 
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(StateBackend) - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
 
bind(StateBackend) - Method in class org.apache.flink.api.common.state.ListStateDescriptor
 
bind(StateBackend) - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
 
bind(StateBackend) - Method in class org.apache.flink.api.common.state.StateDescriptor
Creates a new State on the given StateBackend.
bind(StateBackend) - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
 
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
BitwiseAnd - Class in org.apache.flink.api.table.expressions
 
BitwiseAnd(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.BitwiseAnd
 
BitwiseAnd$ - Class in org.apache.flink.api.table.expressions
 
BitwiseAnd$() - Constructor for class org.apache.flink.api.table.expressions.BitwiseAnd$
 
BitwiseBinaryArithmetic - Class in org.apache.flink.api.table.expressions
 
BitwiseBinaryArithmetic() - Constructor for class org.apache.flink.api.table.expressions.BitwiseBinaryArithmetic
 
BitwiseNot - Class in org.apache.flink.api.table.expressions
 
BitwiseNot(Expression) - Constructor for class org.apache.flink.api.table.expressions.BitwiseNot
 
BitwiseNot$ - Class in org.apache.flink.api.table.expressions
 
BitwiseNot$() - Constructor for class org.apache.flink.api.table.expressions.BitwiseNot$
 
BitwiseOr - Class in org.apache.flink.api.table.expressions
 
BitwiseOr(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.BitwiseOr
 
BitwiseOr$ - Class in org.apache.flink.api.table.expressions
 
BitwiseOr$() - Constructor for class org.apache.flink.api.table.expressions.BitwiseOr$
 
BitwiseXor - Class in org.apache.flink.api.table.expressions
 
BitwiseXor(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.BitwiseXor
 
BitwiseXor$ - Class in org.apache.flink.api.table.expressions
 
BitwiseXor$() - Constructor for class org.apache.flink.api.table.expressions.BitwiseXor$
 
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_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) - Constructor for class org.apache.flink.runtime.blob.BlobCache
 
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) - 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
 
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) - 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).
BlobUtils - Class in org.apache.flink.runtime.blob
Utility class to work with blob data.
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
 
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$
 
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
 
BlockInfo() - Constructor for class org.apache.flink.api.common.io.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
 
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.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.
boolean2Literal(boolean) - Method in interface org.apache.flink.api.scala.table.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
 
BooleanComparator - Class in org.apache.flink.api.common.typeutils.base
 
BooleanComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
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
 
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
 
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
 
boolLiteral() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
boolLiteral() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
Bottou(double) - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Bottou
 
Bottou$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Bottou$
 
boundaries - Variable in class org.apache.flink.api.common.distributions.SimpleDistribution
 
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
 
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
 
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) - 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
 
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
A bucketer is used with a RollingSink to put emitted elements into rolling files.
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.
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 - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
buffer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
bufferedReader() - Method in class org.apache.flink.api.scala.FlinkShell$
 
bufferedReader() - Static method in class org.apache.flink.api.scala.FlinkShell
 
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.
BufferReader - Class in org.apache.flink.runtime.io.network.api.reader
A buffer-oriented reader.
BufferReader(InputGate) - Constructor for class org.apache.flink.runtime.io.network.api.reader.BufferReader
 
BufferRecycler - Interface in org.apache.flink.runtime.io.network.buffer
 
BufferReorderingException(int, int) - Constructor for exception org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel.BufferReorderingException
 
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.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(List<Object>) - Method in interface org.apache.flink.ml.math.VectorBuilder
Builds a Vector of type T from a List[Double]
buildBloomFilterForBucketsInPartition(int, HashPartition<BT, PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
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
 
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
 
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
 
BulkBlockChannelReader - Interface in org.apache.flink.runtime.io.disk.iomanager
 
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
 
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
 
ByteComparator - Class in org.apache.flink.api.common.typeutils.base
 
ByteComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ByteComparator
 
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_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.runtime.state.memory
A state handle that contains stream state in a byte array.
ByteStreamStateHandle(byte[]) - Constructor for class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
Creates a new ByteStreamStateHandle containing the given data.
ByteSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ByteSum
 
ByteSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
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.
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
 

C

c() - Method in class org.apache.flink.api.scala.codegen.MacroContextHolder
 
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.
cachePartitionInfo(PartialInputChannelDeploymentDescriptor) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
calculateHeapSize(int, Configuration) - Static method in class org.apache.flink.yarn.Utils
See documentation
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
 
callback - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
The callback than handles error propagation or logging callbacks
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.
cancel(String[]) - Method in class org.apache.flink.client.CliFrontend
Executes the CANCEL action.
cancel(JobID) - Method in class org.apache.flink.client.program.Client
Cancels a job identified by the job id.
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
 
cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
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.storm.wrappers.SpoutWrapper
Cancels the source.
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileSourceFunction
 
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.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.StreamSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
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.join.WindowJoin.GradeSource
 
cancel() - Method in class org.apache.flink.streaming.examples.join.WindowJoin.SalarySource
 
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
 
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.
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$
 
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) - 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, Exception) - Method in class org.apache.flink.runtime.webmonitor.StackTraceSampleCoordinator
Cancels a pending sample.
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.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() - 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
 
canContainFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
canContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
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.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.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.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.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.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 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.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.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.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.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.api.table.Row
 
canEqual(Object) - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
canEqual(Object) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
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.MultiplexingStreamRecordSerializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
canNotContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
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.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.
CAR_DATA - Static variable in class org.apache.flink.streaming.examples.windowing.util.TopSpeedWindowingExampleData
 
CarEvent(int, int, double, long) - Constructor for class org.apache.flink.examples.scala.StreamingTableFilter.CarEvent
 
CarEvent(int, int, double, long) - Constructor for class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent
 
CarEvent$() - Constructor for class org.apache.flink.examples.scala.StreamingTableFilter.CarEvent$
 
CarEvent$() - Constructor for class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent$
 
carId() - Method in class org.apache.flink.examples.scala.StreamingTableFilter.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
 
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
 
cast(TypeInformation<?>) - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
Cast - Class in org.apache.flink.api.table.expressions
 
Cast(Expression, TypeInformation<?>) - Constructor for class org.apache.flink.api.table.expressions.Cast
 
cast() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
cast() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
Cast$ - Class in org.apache.flink.api.table.expressions
 
Cast$() - Constructor for class org.apache.flink.api.table.expressions.Cast$
 
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.StackTraceSampleMessages.ResponseStackTraceSampleFailure
 
cause() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError
 
cause() - Method in class org.apache.flink.runtime.messages.TaskMessages.FailTask
 
cbf() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
CCMessenger() - Constructor for class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
 
CCUpdater() - Constructor for class org.apache.flink.graph.library.ConnectedComponents.CCUpdater
 
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
 
CEPPatternOperator<IN> - Class in org.apache.flink.cep.operator
CEP pattern operator implementation which is used for non keyed streams.
CEPPatternOperator(TypeSerializer<IN>, boolean, NFACompiler.NFAFactory<IN>) - Constructor for class org.apache.flink.cep.operator.CEPPatternOperator
 
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$
 
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.
chainPredictor(P) - Method in interface org.apache.flink.ml.pipeline.Transformer
Chains a Transformer with a Predictor to form a ChainedPredictor.
chainTransformer(T) - Method in interface org.apache.flink.ml.pipeline.Transformer
Chains two Transformer to form a ChainedTransformer.
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.RMQSource
 
channelIndex - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
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, 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.RuntimeMonitorHandler
 
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_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
 
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
 
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.
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$
 
checkAndCoSort(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
checkAndExtractLambdaMethod(Function) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
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
 
checkArgument(boolean) - Static method in class org.apache.flink.streaming.connectors.kafka.util.KafkaUtils
 
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.runtime.util.MathUtils
Casts the given value to a 32 bit integer, if it can be safely done.
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<?>) - 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$
 
CheckGroupExpression() - Method in class org.apache.flink.api.table.expressions.analysis.GroupByAnalyzer
 
CheckGroupExpression() - Constructor for class org.apache.flink.api.table.expressions.analysis.GroupByAnalyzer.CheckGroupExpression
 
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
 
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
 
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.runtime.state.filesystem.FsStateBackendFactory
The key under which the config stores the directory where checkpoints should be stored
CheckpointBarrier - Class in org.apache.flink.runtime.io.network.api
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
CheckpointBarrier() - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
CheckpointBarrier(long, long) - 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.
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
 
CheckpointCoordinator - Class in org.apache.flink.runtime.checkpoint
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
CheckpointCoordinator(JobID, long, long, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], ClassLoader, CheckpointIDCounter, CompletedCheckpointStore, RecoveryMode) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
CheckpointCoordinator(JobID, long, long, long, int, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], ClassLoader, CheckpointIDCounter, CompletedCheckpointStore, RecoveryMode, CheckpointStatsTracker) - 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, UUID) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
 
Checkpointed<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
This method must be implemented by functions that have state that needs to be checkpointed.
CheckpointedAsynchronously<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
This interface marks a function/operator as asynchronously checkpointed.
checkpointId - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
 
checkpointIdCounter - Variable in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Checkpoint ID counter to ensure ascending IDs.
CheckpointIDCounter - Interface in org.apache.flink.runtime.checkpoint
A checkpoint ID counter.
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.
checkpointPath - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
Where we should put RocksDB backups
checkpointPath - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
FileSystem path where checkpoints are stored
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
 
CheckpointStateOutputStream() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend.CheckpointStateOutputStream
 
CheckpointStateOutputView(AbstractStateBackend.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend.CheckpointStateOutputView
 
checkpointStateSerializable(S, long, long) - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
checkpointStateSerializable(S, long, long) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
checkpointStateSerializable(S, long, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Writes the given state into the checkpoint, and returns a handle that can retrieve the state back.
checkpointStateSerializable(S, long, long) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
checkpointStateSerializable(S, long, long) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
Serialized the given state into bytes using Java serialization and creates a state handle that can re-create that state.
CheckpointStats - Class in org.apache.flink.runtime.checkpoint.stats
Statistics for a specific checkpoint.
CheckpointStats(long, long, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
Creates a checkpoint statistic.
CheckpointStatsTracker - Interface in org.apache.flink.runtime.checkpoint.stats
A tracker for checkpoint statistics.
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(LocalProperties, LocalProperties, int) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
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
Convenience method to get the count (number of elements) of a DataSet as well as the checksum (sum over element hashes).
checksumHashCode(Graph) - Static method in class org.apache.flink.graph.utils.GraphUtils
Computes the checksum over the Graph
ChecksumHashCodeHelper(String) - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
checkTimerException() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
checkValidArguments(Vector, Vector) - Method in interface org.apache.flink.ml.metrics.distances.DistanceMetric
 
child() - Method in class org.apache.flink.api.table.expressions.Abs
 
child() - Method in class org.apache.flink.api.table.expressions.Avg
 
child() - Method in class org.apache.flink.api.table.expressions.BitwiseNot
 
child() - Method in class org.apache.flink.api.table.expressions.Cast
 
child() - Method in class org.apache.flink.api.table.expressions.Count
 
child() - Method in class org.apache.flink.api.table.expressions.IsNotNull
 
child() - Method in class org.apache.flink.api.table.expressions.IsNull
 
child() - Method in class org.apache.flink.api.table.expressions.Max
 
child() - Method in class org.apache.flink.api.table.expressions.Min
 
child() - Method in class org.apache.flink.api.table.expressions.Naming
 
child() - Method in class org.apache.flink.api.table.expressions.Not
 
child() - Method in class org.apache.flink.api.table.expressions.Sum
 
child() - Method in class org.apache.flink.api.table.expressions.UnaryExpression
 
child() - Method in class org.apache.flink.api.table.expressions.UnaryMinus
 
children() - Method in class org.apache.flink.api.table.expressions.BinaryExpression
 
children() - Method in class org.apache.flink.api.table.expressions.LeafExpression
 
children() - Method in class org.apache.flink.api.table.expressions.Substring
 
children() - Method in class org.apache.flink.api.table.expressions.UnaryExpression
 
children() - Method in class org.apache.flink.api.table.plan.Aggregate
 
children() - Method in class org.apache.flink.api.table.plan.As
 
children() - Method in class org.apache.flink.api.table.plan.Filter
 
children() - Method in class org.apache.flink.api.table.plan.GroupBy
 
children() - Method in class org.apache.flink.api.table.plan.Join
 
children() - Method in class org.apache.flink.api.table.plan.Root
 
children() - Method in class org.apache.flink.api.table.plan.Select
 
children() - Method in class org.apache.flink.api.table.plan.UnionAll
 
children() - Method in class org.apache.flink.api.table.trees.TreeNode
List of child nodes that should be considered when doing transformations.
choices(String...) - Method in class org.apache.flink.api.java.utils.Option
Restrict the list of possible values of the parameter.
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
 
CLASS_OPTION - Static variable in class org.apache.flink.client.cli.CliFrontendParser
 
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.
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
 
clean(Object, boolean) - Static method in class org.apache.flink.api.java.ClosureCleaner
 
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) - 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.
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(Logger, Closeable...) - Static method in class org.apache.flink.runtime.util.IOUtils
Close the Closeable objects and ignore any IOException or null pointers.
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.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 interface org.apache.flink.streaming.runtime.io.StreamingReader
 
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
 
cleanupFailedCheckpoints(String, Connection, long, long) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Clean up states between the checkpoint and recovery timestamp.
cleanupFailedCheckpoints(String, Connection, long, long) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
cleanupInterval() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerConfiguration
 
cleanUpOperatorStatsCache() - Method in class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Cleans up the operator stats cache if it contains timed out entries.
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.LazyDbValueState
 
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.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
 
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.state.AbstractHeapState
 
clear() - Method in class org.apache.flink.runtime.state.GenericFoldingState
 
clear() - Method in class org.apache.flink.runtime.state.GenericListState
 
clear() - Method in class org.apache.flink.runtime.state.GenericReducingState
 
clear() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
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.runtime.util.UnionIterator
 
clear() - Method in class org.apache.flink.storm.util.StormConfig
 
clear() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Remove all registered nodes etc.
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() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
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.
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
 
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
 
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 - Class in org.apache.flink.client.program
Encapsulates the functionality necessary to submit a program to a remote cluster.
Client(Configuration) - Constructor for class org.apache.flink.client.program.Client
Creates a instance that submits the programs to the JobManager defined in the configuration.
Client(Configuration, int) - Constructor for class org.apache.flink.client.program.Client
Creates a new instance of the class that submits the jobs to a job-manager.
client - Variable in class org.apache.flink.client.program.ContextEnvironment
 
client() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
CLIENT_CONNECT_TIMEOUT_SECONDS - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
ClientShutdownHook() - Constructor for class org.apache.flink.yarn.FlinkYarnCluster.ClientShutdownHook
 
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 - 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.Histogram
 
clone() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
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.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.contrib.operatorstatistics.OperatorStatistics
 
clone() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsAccumulator
 
clone() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
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.streaming.connectors.kafka.internals.metrics.AvgKafkaMetricAccumulator
 
clone() - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
clone() - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.MaxKafkaMetricAccumulator
 
clone() - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.MinKafkaMetricAccumulator
 
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.TableInputFormat
 
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 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.contrib.streaming.state.DbStateBackend
 
close() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
close() - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
close() - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection.ShardedStatement
 
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.examples.java.distcp.FileCopyTaskInputFormat
 
close() - Method in class org.apache.flink.graph.examples.utils.ExampleUtils.PrintingOutputFormatWithMessage
 
close() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
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.BlobClient
 
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 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.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.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
 
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.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.SimpleCloseableInputProvider
 
close() - Method in class org.apache.flink.runtime.state.AbstractStateBackend.CheckpointStateOutputView
 
close() - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Closes the state backend, releasing all internal resources, but does not delete any persistent checkpoint data.
close() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
close() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend.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.memory.MemoryStateBackend
 
close() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend.MemoryCheckpointOutputStream
 
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.FileSourceFunction
 
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.operators.AbstractStreamOperator
close() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
close() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
close() - Method in class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
 
close() - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
 
close() - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
 
close() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
close() - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaAllWindowFunctionWrapper
 
close() - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunctionWrapper
 
close() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
 
close() - Method in class org.apache.flink.streaming.connectors.flume.FlumeSink
 
close() - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
 
close() - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
close() - Method in class org.apache.flink.streaming.connectors.fs.StringWriter
 
close() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
Closes the Writer.
close() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
 
close() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
close() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
 
close() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Tries to close the queue.
close() - Method in interface org.apache.flink.streaming.connectors.kafka.internals.Fetcher
Closes the fetcher.
close() - Method in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher
 
close() - Method in interface org.apache.flink.streaming.connectors.kafka.internals.OffsetHandler
Closes the offset handler, releasing all resources.
close() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
 
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.TimestampsAndPeriodicWatermarksOperator
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
close() - Method in interface org.apache.flink.util.Collector
Closes the collector.
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.
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.MemoryStateBackend.MemoryCheckpointOutputStream
Closes the stream and returns the byte array containing the stream's data.
closeAndGetHandle() - Method in class org.apache.flink.runtime.state.AbstractStateBackend.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.AbstractStateBackend.CheckpointStateOutputView
Closes the stream and gets a state handle that can create a DataInputView.
closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend.FsCheckpointStateOutputStream
 
closeAndGetHandle() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend.MemoryCheckpointOutputStream
 
closeAndGetPath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend.FsCheckpointStateOutputStream
Closes the stream and returns the path to the file that contains the stream's data.
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.
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.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
 
closeFunction(Function) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
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
 
closeSocket(Socket) - Static method in class org.apache.flink.runtime.util.IOUtils
Closes the socket ignoring IOException.
closeStream(Closeable) - Static method in class org.apache.flink.runtime.util.IOUtils
Closes the stream ignoring IOException.
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.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
 
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.
ClosureCleaner - Class in org.apache.flink.api.java
 
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() - Method in interface org.apache.flink.test.util.FlinkTestBase
 
cluster - Static variable in class org.apache.flink.test.util.MultipleProgramsTestBase
 
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
 
CMHeavyHitterMergeException(String) - Constructor for exception org.apache.flink.contrib.operatorstatistics.heavyhitters.CountMinHeavyHitter.CMHeavyHitterMergeException
 
code() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.GeneratedExpression
 
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
 
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>) - 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.
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 CoGroped 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.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(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() - 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(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(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(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
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(T) - Method in class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
 
collect(T) - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
 
collect(T) - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
 
collect(T) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
collect(T) - Method in interface org.apache.flink.util.Collector
Emits a record.
collectBuffer(Collector, 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.
collectCountDistinct - Variable in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
collectHeavyHitters - Variable in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
CollectHelper(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.Utils.CollectHelper
 
collection - Variable in class org.apache.flink.api.common.operators.util.FieldSet
 
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
 
CollectionTestEnvironment - Class in org.apache.flink.test.util
 
CollectionTestEnvironment() - Constructor for class org.apache.flink.test.util.CollectionTestEnvironment
 
collectMax - Variable in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
collectMin - Variable in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
collector - Variable in class org.apache.flink.storm.util.AbstractLineSpout
 
Collector<T> - Interface in org.apache.flink.util
Collects a record and forwards it.
collectStackTraces(int, ExecutionAttemptID, List<StackTraceElement[]>) - Method in class org.apache.flink.runtime.webmonitor.StackTraceSampleCoordinator
Collects stack traces of a task.
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.
collectWithTimestamp(T, long) - Method in class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
 
collectWithTimestamp(T, long) - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
 
collectWithTimestamp(T, long) - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
 
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
 
CoMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
A CoFlatMapFunction implements a map() transformation over two connected streams.
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<T>, Collector<T>) - Method in class org.apache.flink.api.java.operators.DistinctOperator.DistinctFunction
 
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<T>, Collector<T>) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator.AggregatingUdf
 
combine(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.api.table.runtime.ExpressionAggregateFunction
 
combine(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.api.table.runtime.NoExpressionAggregateFunction
 
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
 
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>) - 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.
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) - 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) - 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) - 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
 
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
 
commit(Map<KafkaTopicPartition, Long>) - Method in interface org.apache.flink.streaming.connectors.kafka.internals.OffsetHandler
Commits the given offset for the partitions.
commit(Map<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
 
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)
commitOffsets(HashMap<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Utility method to commit offsets.
commitOffsets(HashMap<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
commitOffsets(HashMap<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
CommonRangeBoundaries<T> - Class in org.apache.flink.api.common.distributions
 
CommonRangeBoundaries(TypeComparator<T>, Object[][]) - Constructor for class org.apache.flink.api.common.distributions.CommonRangeBoundaries
 
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(Integer, 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
 
compactKvStates(String, Connection, long, long) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Compact the states between two checkpoint timestamp by only keeping the most recent.
compactKvStates(String, Connection, long, long) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
ComparableAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
 
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
 
Comparator() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.Comparator
 
comparatorOrders() - Method in class org.apache.flink.api.table.typeinfo.RowTypeInfo
Temporary variable for directly passing orders to comparators.
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
comparators() - Method in class org.apache.flink.api.table.typeinfo.RowComparator
null-aware 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(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Compares two records in serialized from.
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.PojoComparator
 
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(T, T) - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
compare(Row, Row) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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(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) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
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
 
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
 
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.BooleanComparator
 
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.CharComparator
 
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.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.IntComparator
 
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.ShortComparator
 
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.TypeComparator
Compares two records in serialized from.
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.PojoComparator
 
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.table.typeinfo.NullAwareComparator
This method is not implemented here.
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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(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(BlockLocation) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
 
compareTo(InstanceConnectionInfo) - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
 
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(Pair<U, V>) - Method in class org.apache.flink.types.Pair
 
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(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
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.PojoComparator
 
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<T>) - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
compareToReference(TypeComparator<Row>) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
comparison() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
comparison() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
compile(Pattern<T, ?>, TypeSerializer<T>) - 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.
compiledFilter() - Method in class org.apache.flink.api.table.runtime.ExpressionFilterFunction
 
compiledJoin() - Method in class org.apache.flink.api.table.runtime.ExpressionJoinFunction
 
compiledSelect() - Method in class org.apache.flink.api.table.runtime.ExpressionSelectFunction
 
compileFactory(Pattern<T, ?>, TypeSerializer<T>) - 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() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
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
 
CompletedCheckpoint - Class in org.apache.flink.runtime.checkpoint
A successful checkpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered completed.
CompletedCheckpoint(JobID, long, long, long, ArrayList<StateForTask>) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
CompletedCheckpointStore - Interface in org.apache.flink.runtime.checkpoint
A bounded LIFO-queue of CompletedCheckpoint instances.
ComponentIdFilter() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents.ComponentIdFilter
 
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
 
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
 
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.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
 
ComputationState<T> - Class in org.apache.flink.cep.nfa
Helper class which encapsulates the state of the NFA computation.
ComputationState(State<T>, T, long, DeweyNumber, long) - Constructor for class org.apache.flink.cep.nfa.ComputationState
 
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
 
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.
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
 
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
 
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.
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.
CONF_FILE() - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
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.test.util.AbstractTestBase
Configuration to start the testing cluster with
config() - Method in class org.apache.flink.yarn.YarnMessages.StartYarnSession
 
CONFIG_FILE_LOG4J_NAME - Static variable in class org.apache.flink.client.FlinkYarnSessionCli
 
CONFIG_FILE_LOGBACK_NAME - Static variable in class org.apache.flink.client.FlinkYarnSessionCli
 
CONFIG_KEY - Static variable in class org.apache.flink.api.common.ExecutionConfig
 
CONFIG_KEY_BULK_FLUSH_INTERVAL_MS - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
 
CONFIG_KEY_BULK_FLUSH_MAX_ACTIONS - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
 
CONFIG_KEY_BULK_FLUSH_MAX_SIZE_MB - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
 
ConfigConstants - Class in org.apache.flink.configuration
This class contains all constants for the configuration.
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
 
configuration() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerConfiguration
 
configure(Configuration) - Method in class org.apache.flink.addons.hbase.TableInputFormat
creates a Scan object and a 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 andge 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.examples.java.distcp.FileCopyTaskInputFormat
 
configure(Configuration) - Method in class org.apache.flink.graph.examples.utils.ExampleUtils.PrintingOutputFormatWithMessage
 
configure(GSAConfiguration) - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Configures this gather-sum-apply 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_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
 
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
 
connecDataSet(IntermediateDataSet) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
 
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
 
connectDataSetAsInput(IntermediateDataSet, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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 - Class in org.apache.flink.graph.examples
This example shows how to use Gelly's library methods.
ConnectedComponents() - Constructor for class org.apache.flink.graph.examples.ConnectedComponents
 
ConnectedComponents<K,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> - Class in org.apache.flink.graph.library
Distributes the minimum ID associated with a given vertex among all the target vertices.
ConnectedComponents.CCUpdater<K> - Class in org.apache.flink.graph.library
Updates the value of a vertex by picking the minimum neighbor ID 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
 
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
 
connectIdInput(IntermediateDataSetID, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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(InstanceConnectionInfo, 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
 
connectionInfo() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
ConnectionManager - Interface in org.apache.flink.runtime.io.network
The connection manager manages physical connections for the (logical) remote input channels at runtime.
connections() - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
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) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType, boolean) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
ConnectorSource<OUT> - Class in org.apache.flink.streaming.api.functions.source
 
ConnectorSource(DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.ConnectorSource
 
connectSource(int, IntermediateResult, JobEdge, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
connectToCluster() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Connect the FlinkYarnCluster to the ApplicationMaster.
connectToCluster() - Method in class org.apache.flink.yarn.FlinkYarnCluster
Connect the FlinkYarnCluster to the ApplicationMaster.
connectToPredecessors(Map<IntermediateDataSetID, IntermediateResult>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
Constant$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Constant$
 
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
 
constructLogString(String, String, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
Utility function that composes a string for logging purposes.
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
 
containerContains(String) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
containerHasReferences() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
containerLaunchContext() - Method in class org.apache.flink.yarn.YarnJobManager
 
containers() - Method in class org.apache.flink.yarn.YarnMessages.YarnContainersAllocated
 
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(K, V, long) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Checks whether the given key, value, timestamp triple is contained in the shared buffer
contains(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
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
 
containsKey(String) - Method in class org.apache.flink.configuration.Configuration
Checks whether there is an entry with the specified key
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
 
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.
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
 
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(W, WindowBuffer<IN, ACC>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
Context(DataInputView, ClassLoader) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
context - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
Context(K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
ContextEnvironment - Class in org.apache.flink.client.program
Execution Environment for remote execution with the Client.
ContextEnvironment(Client, List<URL>, List<URL>, ClassLoader, String) - 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(Client, List<URL>, List<URL>, ClassLoader, int, boolean, String) - Constructor for class org.apache.flink.client.program.ContextEnvironmentFactory
 
ContinuousEventTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that continuously fires based on a given time interval.
ContinuousProcessingTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that continuously fires based on a given time interval.
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$() - Constructor for class org.apache.flink.ml.optimization.IterativeSolver.ConvergenceThreshold$
 
ConvergenceThreshold$() - Constructor for class org.apache.flink.ml.regression.MultipleLinearRegression.ConvergenceThreshold$
 
convert(Vector<Object>) - Method in interface org.apache.flink.ml.math.BreezeVectorConverter
Converts a Breeze vector into a Flink vector of type T
convertBoxedJavaType(Object) - Static method in class org.apache.flink.types.JavaToValueConverter
 
convertToCommitMap(HashMap<KafkaTopicPartition, Long>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
convertToFlinkKafkaTopicPartition(List<PartitionInfo>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
Converts a list of Kafka PartitionInfo's to Flink's KafkaTopicPartition (which are serializable)
convertToKafkaTopicPartition(List<KafkaTopicPartition>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
convertTypeInfoToTaggedValue(TaggedValue.Input, TypeInformation<?>, String, List<CompositeType.FlatFieldDescriptor>, int[]) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
convertValueType(Value) - Static method in class org.apache.flink.types.JavaToValueConverter
 
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
 
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(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(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(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(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.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() - 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(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(Row, Row) - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
copy(Row) - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
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(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(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(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.HashPartitioner
 
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.MultiplexingStreamRecordSerializer
 
copy(StreamElement, StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
copy(T) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Creates a copy of this stream record.
copy(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
copy(StreamRecord<T>, StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
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() - 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
 
copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.flink.runtime.util.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream) - Static method in class org.apache.flink.runtime.util.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, boolean) - Static method in class org.apache.flink.runtime.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
 
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
 
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
 
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
 
copyTo(int, MemorySegment, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk copy method.
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
 
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
 
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
 
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
 
count() - Method in class org.apache.flink.api.java.DataSet
Convenience method to get the count (number of elements) of a DataSet.
count() - Method in class org.apache.flink.api.scala.DataSet
Convenience method to get the count (number of elements) of a DataSet
count() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
Count - Class in org.apache.flink.api.table.expressions
 
Count(Expression) - Constructor for class org.apache.flink.api.table.expressions.Count
 
COUNT() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
count() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
COUNT() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
count() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
count - Variable in class org.apache.flink.examples.java.JavaTableExample.WC
 
count() - Method in class org.apache.flink.examples.scala.WordCountTable.WC
 
count - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
Count$ - Class in org.apache.flink.api.table.expressions
 
Count$() - Constructor for class org.apache.flink.api.table.expressions.Count$
 
CountAppender() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.CountAppender
 
countBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
countDistinctAlgorithm - Variable in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
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 - Variable in class org.apache.flink.storm.util.InMemorySpout
 
counterId - Static variable in class org.apache.flink.storm.wordcount.WordCountTopology
 
CountEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
An Evictor that keeps only a certain amount of elements.
CountHelper(String) - Constructor for class org.apache.flink.api.java.Utils.CountHelper
 
CountMinHeavyHitter - Class in org.apache.flink.contrib.operatorstatistics.heavyhitters
 
CountMinHeavyHitter(double, double, double, int) - Constructor for class org.apache.flink.contrib.operatorstatistics.heavyhitters.CountMinHeavyHitter
 
CountMinHeavyHitter(CountMinSketch, double) - Constructor for class org.apache.flink.contrib.operatorstatistics.heavyhitters.CountMinHeavyHitter
 
CountMinHeavyHitter.CMHeavyHitterMergeException - Exception in org.apache.flink.contrib.operatorstatistics.heavyhitters
 
COUNTS - Static variable in class org.apache.flink.test.testdata.WordCountData
 
COUNTS_AS_TUPLES - Static variable in class org.apache.flink.test.testdata.WordCountData
 
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.
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(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
Opens an FSDataOutputStream at the indicated Path.
create(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Opens an FSDataOutputStream at the indicated Path.
create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
create(Path, boolean) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
create(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
Creates a FixedDelayRestartStrategy from the given Configuration.
create(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
Creates a NoRestartStrategy instance.
create(Path, boolean, int, short, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
create(Path, boolean) - 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, boolean) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
create(String, JobID, ExecutionAttemptID, InputGateDeploymentDescriptor, NetworkEnvironment) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Creates an input gate and all of its input channels.
create() - Static method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
Gets the default instance of this state backend, using the default maximal state size.
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 class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer.Factory
 
create() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer.Factory
 
create() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer.Factory
 
create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBufferFactory
Creates a new WindowBuffer.
create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.LazyFactory
The factory method; creates the value.
create(int, TypeInformation<R>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.FieldAccessor
 
create(String, TypeInformation<R>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.FieldAccessor
 
createActivatorDeactivator(ActorSystem, UUID) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
createActivatorDeactivator(ActorSystem, UUID) - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
 
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, 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.
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
 
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
 
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.
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, boolean) - 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, boolean) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
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.
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.
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.
createCheckpointsTable(String, Connection) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Initialize tables for storing non-partitioned checkpoints for the given job id and database connection.
createCheckpointsTable(String, Connection) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Creates an output stream that writes into the state of the given checkpoint.
createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createCheckpointStateOutputView(long, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Creates a DataOutputView stream that writes into the state of the given checkpoint.
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.
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(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() - 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(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.table.typeinfo.RowTypeInfo
 
createComparator(FieldList, boolean[], T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
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(JobID, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Creates a CompletedCheckpointStore instance for a job.
createCompletedCheckpoints(JobID, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
createCompletedCheckpoints(JobID, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
createCompletedCheckpoints(CuratorFramework, Configuration, JobID, int, ClassLoader) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createConfiguration(String, String) - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
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.types.Record
Creates an exact copy of this record.
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.
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.
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
 
createDetailsForJob(ExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
createEmptySchema() - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
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.
createFinalPlan(List<SinkPlanNode>, String, Plan) - Method in class org.apache.flink.optimizer.traversals.PlanFinalizer
 
createFlinkYarnClient(CommandLine) - Method in class org.apache.flink.client.FlinkYarnSessionCli
Creates a new Yarn Client.
createFoldingState(FoldingStateDescriptor<T, ACC>) - Method in interface org.apache.flink.api.common.state.StateBackend
Creates and returns a new FoldingState.
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Creates and returns a new FoldingState.
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createFor(Metric) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
createFromConfig(Configuration) - Static method in class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
Creates a SavepointStore from the specified Configuration.
createFromConfig(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Creates a RestartStrategy instance from the given Configuration.
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.
createFsState(FsStateBackend, HashMap<N, Map<K, SV>>) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
 
createFsState(FsStateBackend, HashMap<N, Map<K, ACC>>) - Method in class org.apache.flink.runtime.state.filesystem.FsFoldingState.Snapshot
 
createFsState(FsStateBackend, HashMap<N, Map<K, ArrayList<V>>>) - Method in class org.apache.flink.runtime.state.filesystem.FsListState.Snapshot
 
createFsState(FsStateBackend, HashMap<N, Map<K, V>>) - Method in class org.apache.flink.runtime.state.filesystem.FsReducingState.Snapshot
 
createFsState(FsStateBackend, HashMap<N, Map<K, V>>) - Method in class org.apache.flink.runtime.state.filesystem.FsValueState.Snapshot
 
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from the given InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from the given InputFormat.
createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsState
 
createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.FsFoldingState
 
createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.FsListState
 
createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.FsReducingState
 
createHeapSnapshot(Path) - Method in class org.apache.flink.runtime.state.filesystem.FsValueState
 
createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.AbstractMemState
 
createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.MemFoldingState
 
createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.MemListState
 
createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.MemReducingState
 
createHeapSnapshot(byte[]) - Method in class org.apache.flink.runtime.state.memory.MemValueState
 
createInBlockInformation(DataSet<Tuple2<Object, ALS.Rating>>, DataSet<Tuple2<Object, int[]>>, 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, int[]>>, 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
Creates an IndexRequest from an element.
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>) - 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.TableInputFormat
 
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 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.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.LongSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
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.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.TypeSerializer
Creates a new instance of the data type.
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.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.api.table.typeinfo.RowSerializer
 
createInstance() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
createInstance() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
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.MultiplexingStreamRecordSerializer
 
createInstance() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
createInterpreter() - Method in class org.apache.flink.api.scala.FlinkILoop
 
createIterationSourceAndSink(int, int, int, long, int) - 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.
createJobClientActorProps(LeaderRetrievalService, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobClientActor
 
createJobGraph() - Method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
createJobManagerComponents(Configuration, Option<LeaderElectionService>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Create the job manager components as (instanceManager, scheduler, libraryCacheManager, archiverProps, defaultExecutionRetries, delayBetweenRetries, timeout)
createJobManagerComponents(Configuration, Option<LeaderElectionService>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Create the job manager components as (instanceManager, scheduler, libraryCacheManager, archiverProps, defaultExecutionRetries, delayBetweenRetries, timeout)
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
 
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
 
createKVStateTable(String, Connection) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Initialize the necessary tables for the given stateId.
createKVStateTable(String, Connection) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
createLeaderElectionService(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperLeaderElectionService instance and a new CuratorFramework client.
createLeaderElectionService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperLeaderElectionService instance.
createLeaderRetrievalService() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Creates a LeaderRetrievalService based on the provided Configuration object.
createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
Creates a StandaloneLeaderRetrievalService from the given configuration.
createLeaderRetrievalService(Configuration, String) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
Creates a StandaloneLeaderRetrievalService form the given configuration and the JobManager name.
createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBackend
Creates and returns a new ListState.
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Creates and returns a new ListState.
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
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.
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.
createMemState(HashMap<N, Map<K, SV>>) - Method in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
 
createMemState(HashMap<N, Map<K, ACC>>) - Method in class org.apache.flink.runtime.state.memory.MemFoldingState.Snapshot
 
createMemState(HashMap<N, Map<K, ArrayList<V>>>) - Method in class org.apache.flink.runtime.state.memory.MemListState.Snapshot
 
createMemState(HashMap<N, Map<K, V>>) - Method in class org.apache.flink.runtime.state.memory.MemReducingState.Snapshot
 
createMemState(HashMap<N, Map<K, V>>) - Method in class org.apache.flink.runtime.state.memory.MemValueState.Snapshot
 
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
 
createOptions(Options) - Method in interface org.apache.flink.contrib.streaming.state.OptionsFactory
This method should set the additional options on top of the current options object.
createOptions() - Method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
Creates the options for this pre-defined setting.
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, int[]>>, 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, int[]>>, int, ALS.BlockIDGenerator) - Static method in class org.apache.flink.ml.recommendation.ALS
Creates the outgoing block information
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
 
createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator
 
createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingProcessingTimeWindowOperator
 
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
 
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
 
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).
createReadView(BufferProvider) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
createReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBackend
Creates and returns a new ReducingState.
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Creates and returns a new ReducingState.
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
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, URL[], URL[]) - Static method in class org.apache.flink.api.common.PlanExecutor
Creates an executor that runs the plan on a remote environment.
createRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
createResult() - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
 
createResult(CompositeType<T>, Seq<Expression>, Function1<String, String>) - Method in class org.apache.flink.api.table.codegen.GenerateResultAssembler
 
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.spargel.ScatterGatherIteration
Creates the operator that represents this scatter-gather graph computation.
createRocksDBSnapshot(URI, long) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
createRocksDBSnapshot(URI, long) - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
 
createRocksDBSnapshot(URI, long) - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
 
createRocksDBSnapshot(URI, long) - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
 
createRocksDBSnapshot(URI, long) - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
 
createRocksDBState(TypeSerializer<K>, TypeSerializer<N>, SD, File, String, String, Options) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
Subclasses must implement this for creating a concrete RocksDB state.
createRuntimeContext() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
createRuntimeContext() - 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
 
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.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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.table.typeinfo.RowTypeInfo
 
createSerializer(T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
createShardedConnection() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Creates a new ShardedConnection using the set parameters.
CreateSimilarUserEdges() - Constructor for class org.apache.flink.graph.examples.MusicProfiles.CreateSimilarUserEdges
 
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.
createStateBackend(String, TypeSerializer<?>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
createStatistics(List<FileStatus>, FileInputFormat.FileBaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
Fill in the statistics.
createSubmittedJobGraphs(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createSubpartitionView(int, BufferProvider) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Returns the requested subpartition.
createSubpartitionView(ResultPartitionID, int, BufferProvider) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
createSubpartitionView(ResultPartitionID, int, BufferProvider) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
Returns the requested intermediate result partition input view.
createTable(DataSet<A>, CompositeType<A>, Expression[], Seq<Tuple2<String, TypeInformation<?>>>) - Method in class org.apache.flink.api.java.table.JavaBatchTranslator
 
createTable(DataStream<A>, CompositeType<A>, Expression[], Seq<Tuple2<String, TypeInformation<?>>>) - Method in class org.apache.flink.api.java.table.JavaStreamingTranslator
 
createTable(DataSet<A>, Expression[]) - Method in class org.apache.flink.api.scala.table.ScalaBatchTranslator
 
createTable(DataSet<A>, CompositeType<A>, Expression[], Seq<Tuple2<String, TypeInformation<?>>>) - Method in class org.apache.flink.api.scala.table.ScalaBatchTranslator
 
createTable(DataStream<A>, CompositeType<A>, Expression[], Seq<Tuple2<String, TypeInformation<?>>>) - Method in class org.apache.flink.api.scala.table.ScalaStreamingTranslator
 
createTable(Object, CompositeType<A>, Expression[], Seq<Tuple2<String, TypeInformation<?>>>) - Method in class org.apache.flink.api.table.plan.PlanTranslator
Creates a Table from a DataSet or a DataStream (the underlying representation).
createTable(Object) - Method in class org.apache.flink.api.table.plan.PlanTranslator
Creates a Table from the given DataSet or DataStream.
createTable(Object, String) - Method in class org.apache.flink.api.table.plan.PlanTranslator
Creates a Table from the given DataSet or DataStream while only taking those fields mentioned in the field expression.
createTable(Object, Expression[], boolean) - Method in class org.apache.flink.api.table.plan.PlanTranslator
Creates a Table from the given DataSet or DataStream while only taking those fields mentioned in the fields parameter.
createTempFile(String, String) - Method in class org.apache.flink.test.util.AbstractTestBase
 
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
 
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.TupleTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.table.typeinfo.RowTypeInfo
 
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
 
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
 
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.
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.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.StringParser
 
createValue() - Method in class org.apache.flink.types.parser.StringValueParser
 
createValueState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBackend
Creates and returns a new ValueState.
createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Creates and returns a new ValueState.
createValueState(TypeSerializer<N>, ValueStateDescriptor<V>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createValueState(TypeSerializer<N>, ValueStateDescriptor<V>) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createWorksetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
createWorksetUpdateOutputCollector() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
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>) - 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>) - 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>) - 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.
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
 
ctor() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
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.
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.
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() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
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
 
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.contrib.streaming.state.AbstractRocksDBState
The current key, which the next value methods will refer to
currentKey - Variable in class org.apache.flink.runtime.state.AbstractHeapState
The current key, which the next value methods will refer to
currentKey - Variable in class org.apache.flink.runtime.state.AbstractStateBackend
 
currentlyRunningJobs() - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
currentNamespace - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
The current namespace, which the next value methods will refer to
currentNamespace - Variable in class org.apache.flink.runtime.state.AbstractHeapState
The current namespace, which the access methods will refer to.
currentNSState - Variable in class org.apache.flink.runtime.state.AbstractHeapState
Cache the state map for the current key.
currentRecursionDepth - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The recursion depth of the partition that is currently processed.
currentSplit - Variable in class org.apache.flink.api.common.io.FileInputFormat
The current split that this parallel instance must consume.
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
 
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 - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
To keep track of the current watermark so that we can immediately fire if a trigger registers an event time callback for a timestamp that lies in the past.
currentWatermark - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
To keep track of the current watermark so that we can immediately fire if a trigger registers an event time callback for a timestamp that lies in the past.
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.examples.scala.TPCHQuery3Table.Order
 
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.examples.scala.TPCHQuery3Table.Customer
 
Customer$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Customer$
 
Customer$() - Constructor for class org.apache.flink.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
 

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.ml.math.DenseMatrix
 
data() - Method in class org.apache.flink.ml.math.DenseVector
 
data() - Method in class org.apache.flink.ml.math.SparseMatrix
 
data() - Method in class org.apache.flink.ml.math.SparseVector
 
Data$() - Constructor for class org.apache.flink.examples.scala.ml.LinearRegression.Data$
 
DataDistribution - Interface in org.apache.flink.api.common.distributions
 
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[], 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.instance.InstanceConnectionInfo
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
 
DataSetConversions<T> - Class in org.apache.flink.api.scala.table
Methods for converting a DataSet to a Table.
DataSetConversions(DataSet<T>, CompositeType<T>) - Constructor for class org.apache.flink.api.scala.table.DataSetConversions
 
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.
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
 
DataStreamConversions<T> - Class in org.apache.flink.api.scala.table
 
DataStreamConversions(DataStream<T>, CompositeType<T>) - Constructor for class org.apache.flink.api.scala.table.DataStreamConversions
 
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
 
DataStreamUtils - Class in org.apache.flink.contrib.streaming
 
dataType() - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns the TypeInformation for the elements of this DataStream.
date() - Method in class org.apache.flink.yarn.YarnMessages.YarnMessage
 
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
 
DateTimeBucketer - Class in org.apache.flink.streaming.connectors.fs
A Bucketer that assigns to buckets based on current system time.
DateTimeBucketer() - Constructor for class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
Creates a new DateTimeBucketer with format string "yyyy-MM-dd--HH".
DateTimeBucketer(String) - Constructor for class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
Creates a new DateTimeBucketer with the given date/time format string.
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.
db - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Our RocksDB instance
DbAdapter - Interface in org.apache.flink.contrib.streaming.state
Adapter interface for executing different checkpointing related operations on the underlying database.
DbBackendConfig - Class in org.apache.flink.contrib.streaming.state
Configuration object for DbStateBackend, containing information to shard and connect to the databases that will store the state checkpoints.
DbBackendConfig(String, String, List<String>) - Constructor for class org.apache.flink.contrib.streaming.state.DbBackendConfig
Creates a new sharded database state backend configuration with the given parameters and default MySqlAdapter.
DbBackendConfig(String, String, String) - Constructor for class org.apache.flink.contrib.streaming.state.DbBackendConfig
Creates a new database state backend configuration with the given parameters and default MySqlAdapter.
DbStateBackend - Class in org.apache.flink.contrib.streaming.state
AbstractStateBackend for storing checkpoints in JDBC supporting databases.
DbStateBackend(DbBackendConfig) - Constructor for class org.apache.flink.contrib.streaming.state.DbStateBackend
Create a new DbStateBackend using the provided DbBackendConfig configuration.
DbStateBackend(DbBackendConfig, AbstractStateBackend) - Constructor for class org.apache.flink.contrib.streaming.state.DbStateBackend
Create a new DbStateBackend using the provided DbBackendConfig configuration and a different backend for storing non-partitioned state snapshots.
DbStateHandle<S> - Class in org.apache.flink.contrib.streaming.state
State handle implementation for storing checkpoints as byte arrays in databases using the MySqlAdapter defined in the DbBackendConfig.
DbStateHandle(String, long, long, long, DbBackendConfig, long) - Constructor for class org.apache.flink.contrib.streaming.state.DbStateHandle
 
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
 
decay() - Method in class org.apache.flink.ml.optimization.LearningRateMethod.InvScaling
 
decay() - Method in class org.apache.flink.ml.optimization.LearningRateMethod.Xu
 
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
 
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, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
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) - 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) - Method in interface org.apache.flink.runtime.LeaderSessionMessageFilter
Wrap RequiresLeaderSessionID messages in a LeaderSessionMessage
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() - Method in class org.apache.flink.api.table.TableConfig$
 
DEFAULT() - Static method in class org.apache.flink.api.table.TableConfig
 
Default$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Default$
 
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_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_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_CHANNEL - Static variable in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
IRC channel to join
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_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.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_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_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
Default flag to disable checkpoint stats.
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_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_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_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_TASK_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
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
The default fraction of the free memory allocated by the task manager's memory manager.
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_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.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_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_RECOVERY_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_RECOVERY_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
 
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_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_SAVEPOINT_BACKEND - Static variable in class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
 
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_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_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_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_MEMORY_PRE_ALLOCATE - Static variable in class org.apache.flink.configuration.ConfigConstants
The default setting for TaskManager memory eager allocation of managed memory
DEFAULT_TASK_MANAGER_MEMORY_SEGMENT_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Default size of memory segments in the network stack and the memory manager.
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
Default number of buffers used in the network stack.
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_YARN_APPLICATION_MASTER_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_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
Relative amount of memory to subtract from the requested memory.
DEFAULT_YARN_HEARTBEAT_DELAY() - Method in class org.apache.flink.yarn.YarnJobManager
 
DEFAULT_YARN_MIN_HEAP_CUTOFF - Static variable in class org.apache.flink.configuration.ConfigConstants
Minimum amount of Heap memory to subtract from the requested TaskManager size.
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_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_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_MAX_RETRY_ATTEMPTS - 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_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
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.
DefaultBroadcastVariableInitializer<T> - Class in org.apache.flink.runtime.broadcast
 
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
 
DefaultKafkaMetricAccumulator - Class in org.apache.flink.streaming.connectors.kafka.internals.metrics
 
DefaultLocalClusterFactory() - Constructor for class org.apache.flink.storm.api.FlinkLocalCluster.DefaultLocalClusterFactory
 
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
 
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.
defaultPrimitive(TypeInformation<?>) - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
defaultRestartStrategy() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
defaultTransformDataSetOperation(TransformOperation<Instance, Model, Input, Output>, TypeInformation<Output>, ClassTag<Output>) - Method in class org.apache.flink.ml.pipeline.Transformer$
 
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.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.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.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$
 
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$
 
DELAY_AFTER_REFUSED_REGISTRATION() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
DELAY_AFTER_REFUSED_REGISTRATION() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
delayBetweenSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
delayBetweenSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample
 
DelegatingConfiguration() - Constructor for class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
Default constructor for serialization.
DelegatingConfiguration(Configuration, String) - Constructor for class org.apache.flink.runtime.operators.util.TaskConfig.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(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(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
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.
deleteCheckpoint(String, Connection, long, long, long) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Remove the given checkpoint from the database.
deleteCheckpoint(String, Connection, long, long, long) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
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.NonKeyedWindowOperator.Context
 
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.
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.NonKeyedWindowOperator.Context
 
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
 
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) - 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 - 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.
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
Copies the matrix instance
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
Magnitude of a vector
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 class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
Trigger the deployment to YARN.
deploy() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
deployInternal() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
This method will block until the ApplicationMaster/JobManager have been deployed on YARN.
deployToSlot(SimpleSlot) - Method in class org.apache.flink.runtime.executiongraph.Execution
 
deployToSlot(SimpleSlot) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
depth() - Method in class org.apache.flink.core.fs.Path
Returns the number of elements in this path.
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
desc() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor
 
description() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError
 
description() - Method in class org.apache.flink.runtime.messages.TaskMessages.TaskOperationResult
 
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.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.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.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.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 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(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.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(Row, DataInputView) - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
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(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.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.MultiplexingStreamRecordSerializer
 
deserialize(StreamElement, DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
deserialize(StreamRecord<T>, DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
deserialize(byte[]) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
Deserializes the byte message.
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(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
 
deserializeFlinkAccumulators() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
Gets the Flink (internal) accumulators values.
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
 
deserializeList(ArrayList<byte[]>, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
deserializeObject(byte[], ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializer - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
The schema to convert between Kafka#s byte messages, and Flink's objects
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.util.SerializedValue
 
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, boolean)).
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
 
detached() - Method in class org.apache.flink.yarn.YarnJobManager
 
DetachedEnvironment - Class in org.apache.flink.client.program
Execution Environment for remote execution with the Client in detached mode.
DetachedEnvironment(Client, List<URL>, List<URL>, ClassLoader, String) - Constructor for class org.apache.flink.client.program.DetachedEnvironment
 
DetachedEnvironment.DetachedJobExecutionResult - Class in org.apache.flink.client.program
 
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(int[]) - Constructor for class org.apache.flink.cep.nfa.DeweyNumber
 
diagnostics() - Method in class org.apache.flink.yarn.YarnMessages.LocalStopYarnSession
 
diagnostics() - Method in class org.apache.flink.yarn.YarnMessages.StopYarnSession
 
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.
dim - Variable in class org.apache.flink.api.common.distributions.SimpleDistribution
 
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
 
DirectedOutput(List<OutputSelector<OUT>>, List<Tuple2<Output<StreamRecord<OUT>>, StreamEdge>>) - Constructor for class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
disableAllContextAndOtherEnvironments() - Static method in class org.apache.flink.api.java.ScalaShellRemoteEnvironment
 
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.
disableCleanupOnOpen() - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Disable cleanup of leftover in-progress/pending files when the sink is opened.
disableClosureCleaner() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables the ClosureCleaner.
DisabledCheckpointStatsTracker - Class in org.apache.flink.runtime.checkpoint.stats
A tracker for checkpoint statistics when they are disabled.
DisabledCheckpointStatsTracker() - Constructor for class org.apache.flink.runtime.checkpoint.stats.DisabledCheckpointStatsTracker
 
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.
disableInputCopy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Enable object-reuse for this operator instance.
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.
disableSnaphotCheckpointing() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Disables checkpointing.
disableSysoutLogging() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables the printing of progress update messages to System.out
disassociate() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
discard(ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discard(ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Discards the pending checkpoint, releasing all held resources.
discard(ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.StateForTask
 
discardAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
discardAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
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
 
discardState() - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
 
discardState() - Method in class org.apache.flink.contrib.streaming.state.DbStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.AsynchronousKvStateSnapshot
 
discardState() - Method in class org.apache.flink.runtime.state.AsynchronousStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateHandle
Discard the state by deleting the file that stores the state.
discardState() - Method in interface org.apache.flink.runtime.state.KvStateSnapshot
Discards the state snapshot, removing any resources occupied by it.
discardState() - Method in class org.apache.flink.runtime.state.LocalStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
Discarding the heap state is a no-op.
discardState() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
discardState() - Method in class org.apache.flink.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.runtime.state.StateHandle
Discards the state referred to by this handle, to free up resources in the persistent storage.
discardState() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
Discards all the contained states and sets them to null.
discardState() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
 
Disconnect(String) - Constructor for class org.apache.flink.runtime.messages.Messages.Disconnect
 
disconnect() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Disconnect from the ApplicationMaster without stopping the session (therefore, use the AbstractFlinkYarnCluster.shutdown(boolean) method.
disconnect() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
Disconnect$() - Constructor for class org.apache.flink.runtime.messages.Messages.Disconnect$
 
disconnectFromJobManager() - Method in class org.apache.flink.yarn.ApplicationClient
Disconnects this ApplicationClient from the connected YarnJobManager and cancels the polling timer.
discount() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem
 
discount() - Method in class org.apache.flink.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.AbstractRocksDBState
 
dispose() - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
 
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.AbstractHeapState
 
dispose() - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
dispose() - Method in class org.apache.flink.runtime.state.GenericFoldingState
 
dispose() - Method in class org.apache.flink.runtime.state.GenericListState
 
dispose() - Method in class org.apache.flink.runtime.state.GenericReducingState
 
dispose() - Method in interface org.apache.flink.runtime.state.KvState
Disposes the key/value state, releasing all occupied resources.
dispose() - Method in class org.apache.flink.storm.wrappers.BoltWrapper
 
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 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
 
dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
disposeAllStateForCurrentJob() - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
disposeAllStateForCurrentJob() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
disposeAllStateForCurrentJob() - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Disposes all state associated with the current job.
disposeAllStateForCurrentJob() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
disposeAllStateForCurrentJob() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
disposeAllStateForJob(String, Connection) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Remove all states for the given JobID, by for instance dropping the entire table.
disposeAllStateForJob(String, Connection) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
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.
disposeState(String) - Method in class org.apache.flink.runtime.checkpoint.SavepointStore
 
disposeState(String) - Method in interface org.apache.flink.runtime.checkpoint.StateStore
Disposes the state identified by the given (logical) path.
distance() - Method in class org.apache.flink.examples.scala.StreamingTableFilter.CarEvent
 
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.
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>) - 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.
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
 
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
 
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
 
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<?, ?>>) - 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 - Class in org.apache.flink.api.table.expressions
 
Div(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.Div
 
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.api.table.expressions
 
Div$() - Constructor for class org.apache.flink.api.table.expressions.Div$
 
divideBy(int) - Method in class org.apache.flink.optimizer.costs.Costs
 
DOCS - Static variable in class org.apache.flink.test.testdata.WebLogAnalysisData
 
DOCUMENTS - Static variable in class org.apache.flink.examples.java.relational.util.WebLogData
 
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
double2Literal(double) - Method in interface org.apache.flink.api.scala.table.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
 
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
 
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
 
DoubleSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.DoubleSum
 
DoubleSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
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
 
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.
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
 
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
 
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.
dropLeaderData(List<KafkaTopicPartitionLeader>) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
dropTrivials() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
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
 
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.BooleanComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
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.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.GenericArraySerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
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 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.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.PojoComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
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.TraversableSerializer
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
duplicate() - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
duplicate() - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
duplicate() - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
duplicate() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
duplicate() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
duplicate() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
duplicate() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
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.MultiplexingStreamRecordSerializer
 
duplicate() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
DuplicateValue() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents.DuplicateValue
 
duration() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 

E

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$
 
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
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.JaccardSimilarityMeasureData
 
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
 
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
 
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 - Variable in class org.apache.flink.graph.GraphCsvReader
 
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 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
 
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
 
ElasticsearchSink<T> - Class in org.apache.flink.streaming.connectors.elasticsearch
Sink that emits its input elements to an Elasticsearch cluster.
ElasticsearchSink(Map<String, String>, IndexRequestBuilder<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>, IndexRequestBuilder<T>) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using a TransportClient.
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
 
elementIDs() - Method in class org.apache.flink.ml.recommendation.ALS.InBlockInformation
 
elementIDs() - Method in class org.apache.flink.ml.recommendation.ALS.OutBlockInformation
 
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
 
emit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
emit(T) - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
 
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 interface org.apache.flink.streaming.api.operators.Output
Emits a Watermark from an operator.
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamSource.AutomaticWatermarkContext
 
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
 
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
 
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
emitWindow(NonKeyedWindowOperator<IN, ACC, OUT, W>.Context) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperator
 
emitWindow(NonKeyedWindowOperator<IN, ACC, OUT, W>.Context) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
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.util.IntArrayList
 
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_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.
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) - 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.
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
Enables checkpointing for the streaming job.
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
Method for enabling fault-tolerance.
enableClosureCleaner() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables the ClosureCleaner.
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.
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
 
enableSnapshotCheckpointing(long, long, long, int, List<ExecutionJobVertex>, List<ExecutionJobVertex>, List<ExecutionJobVertex>, ActorSystem, UUID, CheckpointIDCounter, CompletedCheckpointStore, RecoveryMode, StateStore<CompletedCheckpoint>, CheckpointStatsTracker) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
enableSysoutLogging() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables the printing of progress update messages to System.out
end() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
endArray() - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
endIndex() - Method in class org.apache.flink.api.table.expressions.Substring
 
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.
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.Client
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.Client
Tells the JobManager to finish the sessions (jobs) defined by the given IDs.
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
 
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
 
entrySet() - Method in class org.apache.flink.storm.util.StormConfig
 
entrySet() - Method in class org.apache.flink.types.MapValue
 
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
 
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
 
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
Builds triads (triples of vertices) from pairs of edges that share a vertex.
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
 
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
 
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.python.api.PythonPlanBinder
 
ENV_APP_ID - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_CLIENT_HOME_DIR - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_CLIENT_SHIP_FILES - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_CLIENT_USERNAME - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_DETACHED - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_DYNAMIC_PROPERTIES - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_SLOTS - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_STREAMING_MODE - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_TM_COUNT - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
ENV_TM_MEMORY - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
Constants, all starting with ENV_ are used as environment variables to pass values from the Client to the Application Master.
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(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.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.StateDescriptor
 
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.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
 
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.TypeSerializerSingleton
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
 
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.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.PojoSerializer
 
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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
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.SharedBuffer
 
equals(Object) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
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.configuration.Configuration
 
equals(Object) - Method in class org.apache.flink.core.fs.FileInputSplit
 
equals(Object) - Method in class org.apache.flink.core.fs.FileSystem.FSKey
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.ml.common.LabeledVector
 
equals(Object) - Method in class org.apache.flink.ml.math.DenseMatrix
 
equals(Object) - Method in class org.apache.flink.ml.math.DenseVector
 
equals(Object) - Method in class org.apache.flink.ml.math.SparseMatrix
 
equals(Object) - Method in class org.apache.flink.ml.math.SparseVector
 
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) - Method in class org.apache.flink.optimizer.postpass.SparseKeySchema
 
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.StateForTask
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
 
equals(Object) - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
 
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.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 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.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.DeclineCheckpoint
 
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.operators.util.TaskConfig.DelegatingConfiguration
 
equals(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
equals(Object) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
 
equals(Object) - Method in class org.apache.flink.runtime.util.SerializableArrayList
 
equals(Object) - Method in class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
 
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.graph.StreamEdge
 
equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
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.GlobalWindow.Serializer
 
equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
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.MultiplexingStreamRecordSerializer
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
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.Pair
 
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.SerializedValue
 
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) - Method in interface org.apache.flink.ml.math.Matrix
 
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 - Class in org.apache.flink.api.table.expressions
 
EqualTo(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.EqualTo
 
equalTo() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
equalTo() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
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.api.table.expressions
 
EqualTo$() - Constructor for class org.apache.flink.api.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(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
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.PojoComparator
 
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(T) - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
equalToReference(Row) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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.runtime.streamrecord.StreamRecord
 
error() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged
 
errorOccured - Static variable in class org.apache.flink.storm.split.operators.VerifyAndEnrichBolt
 
errors() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.UnsupportedDescriptor
 
escapeHtml(String) - Static method in class org.apache.flink.util.StringUtils
Helper function to escape Strings for display in HTML pages.
estimateCount(Object) - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.CountMinHeavyHitter
 
estimateCountDistinct() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatistics
 
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.
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.
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.
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
 
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
 
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.
evict(Iterable<StreamRecord<Object>>, int, W) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
 
evict(Iterable<StreamRecord<T>>, int, W) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
evict(Iterable<StreamRecord<T>>, int, W) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
Computes how many elements should be removed from the pane.
evict(Iterable<StreamRecord<Object>>, int, W) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
EvictingNonKeyedWindowOperator<IN,ACC,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
Evicting window operator for non-keyed windows.
EvictingNonKeyedWindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, WindowBufferFactory<? super IN, ACC, ? extends EvictingWindowBuffer<IN, ACC>>, AllWindowFunction<ACC, OUT, W>, Trigger<? super IN, ? super W>, Evictor<? super IN, ? super W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperator
 
EvictingWindowBuffer<T,O> - Interface in org.apache.flink.streaming.runtime.operators.windowing.buffers
A WindowBuffer that can also evict elements from the buffer.
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>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
evictionSec() - Method in class org.apache.flink.examples.scala.StreamingTableFilter$
 
evictionSec() - Static method in class org.apache.flink.examples.scala.StreamingTableFilter
 
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 it is being processed and after window evaluation was triggered by a Trigger.
ExampleUtils - Class in org.apache.flink.graph.examples.utils
 
ExampleUtils.PrintingOutputFormatWithMessage<T> - Class in org.apache.flink.graph.examples.utils
 
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.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
 
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
 
exceptionUnwrap(Exception) - Static method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
ExceptionUtils - Class in org.apache.flink.util
 
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
 
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(String) - Method in class org.apache.flink.api.java.ScalaShellRemoteEnvironment
compiles jars from files in the shell virtual directory on the fly, sends and executes it in the remote environment
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() - 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.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() - 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
 
executeProgramBlocking(PackagedProgram, Client, int) - Method in class org.apache.flink.client.CliFrontend
 
executeProgramDetached(PackagedProgram, Client, int) - Method in class org.apache.flink.client.CliFrontend
 
Execution - Class in org.apache.flink.runtime.executiongraph
A single execution of a vertex.
Execution(ExecutionContext, ExecutionVertex, int, long, FiniteDuration) - Constructor for class org.apache.flink.runtime.executiongraph.Execution
 
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.
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.jobmanager.JobManager
The extra execution context, for futures, with a custom logging reporter
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 ExecutionEnviroment 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(ExecutionContext, JobID, String, Configuration, FiniteDuration, RestartStrategy, List<BlobKey>, List<URL>, ClassLoader) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
executionGraph() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.JobFound
 
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
 
executionID() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
executionId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleFailure
 
executionId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleSuccess
 
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.TaskOperationResult
 
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
 
ExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
 
ExecutionJobVertex(ExecutionGraph, JobVertex, int, FiniteDuration) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
ExecutionJobVertex(ExecutionGraph, JobVertex, int, FiniteDuration, long) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
ExecutionJobVertex.PredeterminedInputSplitAssigner - Class in org.apache.flink.runtime.executiongraph
An InputSplitAssigner that assigns to pre-determined hosts.
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$() - Constructor for class org.apache.flink.api.scala.FlinkShell.ExecutionMode$
 
executionModes() - Static method in class org.apache.flink.test.util.MultipleProgramsTestBase
 
ExecutionObserver - Interface in org.apache.flink.runtime.execution
 
ExecutionState - Enum in org.apache.flink.runtime.execution
An enumeration of all states that a task can be in during its execution.
executionStateChanged(ExecutionState, String) - Method in interface org.apache.flink.runtime.execution.ExecutionObserver
Called when the execution state of the associated task has changed.
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$
 
ExecutionVertex - Class in org.apache.flink.runtime.executiongraph
The ExecutionVertex is a parallel subtask of the execution.
ExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], FiniteDuration) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
ExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], FiniteDuration, long) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
executor - Variable in class org.apache.flink.test.util.AbstractTestBase
The mini cluster that runs the test programs
executorService() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
ExecutorThreadFactory - Class in org.apache.flink.runtime.util
 
exists(Function1<A, Object>) - Method in class org.apache.flink.api.table.trees.TreeNode
 
exists(Path) - Method in class org.apache.flink.core.fs.FileSystem
Check if exists.
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.
ExpandAggregations - Class in org.apache.flink.api.table.plan
This is used to expand a Select that contains aggregations.
ExpandAggregations() - Constructor for class org.apache.flink.api.table.plan.ExpandAggregations
 
ExpandAggregations$ - Class in org.apache.flink.api.table.plan
This is used to expand a Select that contains aggregations.
ExpandAggregations$() - Constructor for class org.apache.flink.api.table.plan.ExpandAggregations$
 
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
 
explain(boolean) - Method in class org.apache.flink.api.table.Table
Get the process of the sql parsing, print AST and physical execution plan.The AST show the structure of the supplied statement.
explain() - Method in class org.apache.flink.api.table.Table
 
expr() - Method in class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralBooleanExpression
 
expr() - Method in class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralDoubleExpression
 
expr() - Method in class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralFloatExpression
 
expr() - Method in class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralIntExpression
 
expr() - Method in class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralLongExpression
 
expr() - Method in class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralStringExpression
 
expr() - Method in class org.apache.flink.api.scala.table.ImplicitExpressionConversions.SymbolExpression
 
expr() - Method in class org.apache.flink.api.scala.table.ImplicitExpressionConversions.WithOperations
 
expr() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
expr() - Method in class org.apache.flink.api.table.expressions.Literal
 
Expression - Class in org.apache.flink.api.table.expressions
 
Expression() - Constructor for class org.apache.flink.api.table.expressions.Expression
 
expression() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
expression() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
Expression$ - Class in org.apache.flink.api.table.expressions
 
Expression$() - Constructor for class org.apache.flink.api.table.expressions.Expression$
 
ExpressionAggregateFunction - Class in org.apache.flink.api.table.runtime
 
ExpressionAggregateFunction(Seq<Object>, Seq<AggregationFunction<Object>>) - Constructor for class org.apache.flink.api.table.runtime.ExpressionAggregateFunction
 
ExpressionCodeGenerator<R> - Class in org.apache.flink.api.table.codegen
Base class for all code generation classes.
ExpressionCodeGenerator(Seq<Tuple2<String, CompositeType<?>>>, ClassLoader, TableConfig) - Constructor for class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
ExpressionCodeGenerator.FieldAccessor - Class in org.apache.flink.api.table.codegen
 
ExpressionCodeGenerator.GeneratedExpression - Class in org.apache.flink.api.table.codegen
 
ExpressionCodeGenerator.ObjectFieldAccessor - Class in org.apache.flink.api.table.codegen
 
ExpressionCodeGenerator.ObjectMethodAccessor - Class in org.apache.flink.api.table.codegen
 
ExpressionCodeGenerator.ProductAccessor - Class in org.apache.flink.api.table.codegen
 
ExpressionException - Exception in org.apache.flink.api.table
Exception for all errors occurring during expression evaluation.
ExpressionException(String) - Constructor for exception org.apache.flink.api.table.ExpressionException
 
ExpressionFilterFunction<T> - Class in org.apache.flink.api.table.runtime
Proxy function that takes an expression predicate.
ExpressionFilterFunction(Expression, CompositeType<T>, TableConfig) - Constructor for class org.apache.flink.api.table.runtime.ExpressionFilterFunction
 
ExpressionFilterFunction$ - Class in org.apache.flink.api.table.runtime
 
ExpressionFilterFunction$() - Constructor for class org.apache.flink.api.table.runtime.ExpressionFilterFunction$
 
ExpressionJoinFunction<L,R,O> - Class in org.apache.flink.api.table.runtime
Proxy function that takes an expression predicate and output fields.
ExpressionJoinFunction(Expression, CompositeType<L>, CompositeType<R>, CompositeType<O>, Seq<Expression>, TableConfig) - Constructor for class org.apache.flink.api.table.runtime.ExpressionJoinFunction
 
ExpressionJoinFunction$ - Class in org.apache.flink.api.table.runtime
 
ExpressionJoinFunction$() - Constructor for class org.apache.flink.api.table.runtime.ExpressionJoinFunction$
 
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.api.table.parser.ExpressionParser$
 
expressionList() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
ExpressionParser - Class in org.apache.flink.api.table.parser
 
ExpressionParser() - Constructor for class org.apache.flink.api.table.parser.ExpressionParser
 
ExpressionParser$ - Class in org.apache.flink.api.table.parser
 
ExpressionParser$() - Constructor for class org.apache.flink.api.table.parser.ExpressionParser$
 
ExpressionParser.Keyword - Class in org.apache.flink.api.table.parser
 
ExpressionParser.Keyword$ - Class in org.apache.flink.api.table.parser
 
ExpressionSelectFunction<I,O> - Class in org.apache.flink.api.table.runtime
Proxy function that takes expressions.
ExpressionSelectFunction(CompositeType<I>, CompositeType<O>, Seq<Expression>, TableConfig) - Constructor for class org.apache.flink.api.table.runtime.ExpressionSelectFunction
 
ExpressionSelectFunction$ - Class in org.apache.flink.api.table.runtime
 
ExpressionSelectFunction$() - Constructor for class org.apache.flink.api.table.runtime.ExpressionSelectFunction$
 
extdPrice() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem
 
extdPrice() - Method in class org.apache.flink.examples.scala.TPCHQuery3Table.Lineitem
 
externalJars() - Method in class org.apache.flink.api.scala.FlinkILoop
 
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
 
extractAscendingTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
Extracts the timestamp from the given element.
extractClass(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
ExtractEquiJoinFields - Class in org.apache.flink.api.table.expressions.analysis
Equi-join field extractor for Join Predicates and CoGroup predicates.
ExtractEquiJoinFields() - Constructor for class org.apache.flink.api.table.expressions.analysis.ExtractEquiJoinFields
 
ExtractEquiJoinFields$ - Class in org.apache.flink.api.table.expressions.analysis
Equi-join field extractor for Join Predicates and CoGroup predicates.
ExtractEquiJoinFields$() - Constructor for class org.apache.flink.api.table.expressions.analysis.ExtractEquiJoinFields$
 
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.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.PojoComparator
 
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.table.typeinfo.NullAwareComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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, 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.
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.AscendingTimestampExtractor
 
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(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
 
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.
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(int, 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(FoldFunction<T, ACC>, ACC, TypeSerializer<ACC>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer.Factory
 
Factory(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer.Factory
 
Factory(ReduceFunction<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer.Factory
 
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.ExecutionGraph
 
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
 
failedContainers() - Method in class org.apache.flink.yarn.YarnJobManager
 
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).
FailingHandler() - Constructor for class org.apache.flink.streaming.api.functions.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$
 
failPartitionRequest() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
FailTask(ExecutionAttemptID, Throwable) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.FailTask
 
FailTask$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.FailTask$
 
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.
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 - Static variable in class org.apache.flink.types.BooleanValue
 
FAST_YARN_HEARTBEAT_DELAY() - Method in class org.apache.flink.yarn.YarnJobManager
 
fastEquals(TreeNode<?>) - Method in class org.apache.flink.api.table.trees.TreeNode
Tests for equality by first testing for reference equality.
FatalError(String, Throwable) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError
 
FatalError$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError$
 
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.
fetched - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
fetched - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
Fetcher - Interface in org.apache.flink.streaming.connectors.kafka.internals
A fetcher pulls data from Kafka, from a fix set of partitions.
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.AggregationEntry
 
field - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
FieldAccessFinder - Class in org.apache.flink.api.scala
 
FieldAccessFinder(Map<Class<?>, Set<String>>) - Constructor for class org.apache.flink.api.scala.FieldAccessFinder
 
FieldAccessor() - Constructor for class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.FieldAccessor
 
FieldAccessor<R,F> - Class in org.apache.flink.streaming.util
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.FieldAccessor
 
FieldAccessor.ArrayFieldAccessor<R,F> - Class in org.apache.flink.streaming.util
 
FieldAccessor.PojoFieldAccessor<R,F> - Class in org.apache.flink.streaming.util
 
FieldAccessor.ProductFieldAccessor<R,F> - Class in org.apache.flink.streaming.util
 
FieldAccessor.SimpleFieldAccessor<R> - Class in org.apache.flink.streaming.util
 
FieldAccessor.TupleFieldAccessor<R,F> - Class in org.apache.flink.streaming.util
 
fieldAccessorFor(CompositeType<?>, String) - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
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
 
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() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
Extracts the first field (id 0) from the 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
 
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
 
fieldName() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.ObjectFieldAccessor
 
fieldNames - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
fieldNames() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
fieldNames() - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
fieldNames - Variable in class org.apache.flink.hcatalog.HCatInputFormatBase
 
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.api.table.parser.ExpressionParser$
 
fieldReference() - Static method in class org.apache.flink.api.table.parser.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() - Method in class org.apache.flink.api.table.plan.GroupBy
 
fieldSerializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
fieldSerializers() - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
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).
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 - 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(Configuration) - 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
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
 
FileMonitoringFunction(String, long, FileMonitoringFunction.WatchType) - Constructor for class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
 
FileMonitoringFunction.WatchType - Enum in org.apache.flink.streaming.api.functions.source
 
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.
FileReadFunction - Class in org.apache.flink.streaming.api.functions.source
 
FileReadFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.FileReadFunction
 
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.runtime.state.filesystem
A state handle that points to state stored in a file via Java Serialization.
FileSerializableStateHandle(Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FileSerializableStateHandle
Creates a new FileSerializableStateHandle pointing to state at the given file path.
fileSize - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
FileSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
 
FileSourceFunction(InputFormat<OUT, ?>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.FileSourceFunction
 
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
 
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.runtime.state.filesystem
A state handle that points to state in a file system, accessible as an input stream.
FileStreamStateHandle(Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FileStreamStateHandle
Creates a new FileStreamStateHandle pointing to state at the given file path.
FileSystem - Class in org.apache.flink.core.fs
An abstract base class for a fairly generic file system.
FileSystem() - Constructor for class org.apache.flink.core.fs.FileSystem
 
FileSystem.FSKey - Class in org.apache.flink.core.fs
An auxiliary class to identify a file system by its scheme and its authority.
FileSystem.WriteMode - Enum in org.apache.flink.core.fs
Enumeration for 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.
FileSystemStateStorageHelper<T extends Serializable> - Class in org.apache.flink.runtime.zookeeper.filesystem
StateStorageHelper 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.runtime.util
This is a utility class to deal with temporary files.
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(OUT, Object[]) - Method in class org.apache.flink.api.java.io.TupleCsvInputFormat
 
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>) - 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 - Class in org.apache.flink.api.table.plan
Operation that filters out elements that do not match the predicate expression.
Filter(PlanNode, Expression) - Constructor for class org.apache.flink.api.table.plan.Filter
 
filter(T) - Method in class org.apache.flink.api.table.runtime.ExpressionFilterFunction
 
filter(Expression) - Method in class org.apache.flink.api.table.Table
Filters out elements that don't pass the filter predicate.
filter(String) - Method in class org.apache.flink.api.table.Table
Filters out elements that don't pass the filter predicate.
filter(T) - Method in class org.apache.flink.cep.pattern.AndFilterFunction
 
filter(T) - Method in class org.apache.flink.cep.pattern.SubtypeFilterFunction
 
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$ - Class in org.apache.flink.api.table.plan
 
Filter$() - Constructor for class org.apache.flink.api.table.plan.Filter$
 
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.
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
 
filterFollowings(Long) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets which user to follow.
filterFollowings(Collection<Long>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets which users to follow.
FilterFunction<T> - Interface in org.apache.flink.api.common.functions
A filter function is a predicate applied individually to each record.
filterLanguage(String) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets which language to filter.
filterLanguages(Collection<String>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets which languages to filter.
filterLocation(Location) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets which location to filter.
filterLocations(Collection<Location>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets which locations to filter.
FilterNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a FlatMap 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
 
FilterSongNodes() - Constructor for class org.apache.flink.graph.examples.MusicProfiles.FilterSongNodes
 
FilterVisitsByDate() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterVisitsByDate
 
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.
finalize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
The finalize method shuts down the timer.
finalizeBuildPhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
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
 
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, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
 
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
 
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(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) - 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.
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
 
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>) - 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
 
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.
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.
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
 
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
 
FixedPartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
A partitioner ensuring that each internal Flink partition ends up in one Kafka partition.
FixedPartitioner() - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.FixedPartitioner
 
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.
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>) - 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
 
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<Tuple5<Long, Integer, String, String, String>>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterStreaming.SelectDataFlatMap
 
flatMap(String, Collector<String>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterTopology.SelectLanguageFlatMap
Select the language from the incoming JSON text
flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.streaming.examples.twitter.TwitterStream.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
 
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
 
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, 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.
FLINK_BASE_DIR_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The key to the Flink base directory path
FLINK_JAR_PATH - Static variable in class org.apache.flink.yarn.FlinkYarnClientBase
 
FLINK_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.ConfigConstants
 
FLINK_PYTHON2_BINARY_KEY - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FLINK_PYTHON2_BINARY_PATH - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FLINK_PYTHON3_BINARY_KEY - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FLINK_PYTHON3_BINARY_PATH - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FLINK_PYTHON_DC_ID - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FLINK_PYTHON_FILE_PATH - 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_TMP_DATA_DIR - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FlinkActor - Interface in org.apache.flink.runtime
Base trait for Flink's actors.
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.
flinkConfig() - Method in class org.apache.flink.yarn.ApplicationClient
 
flinkConfiguration() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
FlinkILoop - Class in org.apache.flink.api.scala
 
FlinkILoop(String, int, Option<String[]>, Option<BufferedReader>, PrintWriter) - Constructor for class org.apache.flink.api.scala.FlinkILoop
 
FlinkILoop(String, int, Option<String[]>, BufferedReader, PrintWriter) - Constructor for class org.apache.flink.api.scala.FlinkILoop
 
FlinkILoop(String, int, Option<String[]>) - Constructor for class org.apache.flink.api.scala.FlinkILoop
 
FlinkILoop(String, int, BufferedReader, PrintWriter) - Constructor for class org.apache.flink.api.scala.FlinkILoop
 
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
Deprecated.
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
Deprecated.
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
 
FlinkKafkaConsumerBase(KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Creates a new Flink Kafka Consumer, using the given type of fetcher and offset handler.
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
Deprecated.
FlinkKafkaProducer(String, SerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
Deprecated.
FlinkKafkaProducer(String, SerializationSchema<IN>, Properties, KafkaPartitioner) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
Deprecated.
FlinkKafkaProducer(String, String, KeyedSerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
Deprecated.
FlinkKafkaProducer(String, KeyedSerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
Deprecated.
FlinkKafkaProducer(String, KeyedSerializationSchema<IN>, Properties, KafkaPartitioner) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
Deprecated.
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, KafkaPartitioner<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, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
The main constructor for creating a FlinkKafkaProducer.
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, KafkaPartitioner<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, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducerBase<IN> - Class in org.apache.flink.streaming.connectors.kafka
Flink Sink to produce data into a Kafka topic.
FlinkKafkaProducerBase(String, KeyedSerializationSchema<IN>, Properties, KafkaPartitioner<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.
FlinkMiniCluster - Class in org.apache.flink.runtime.minicluster
Abstract base class for Flink's mini cluster.
FlinkMiniCluster(Configuration, boolean) - Constructor for class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
FlinkMLTools - Class in org.apache.flink.ml.common
FlinkTools 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
FlinkTools 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.
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.ExecutionMode$ - Class in org.apache.flink.api.scala
 
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.
FlinkTestBase - Interface in org.apache.flink.test.util
Mixin to start and stop a ForkableFlinkMiniCluster automatically for Scala based tests.
FlinkTopology - Class in org.apache.flink.storm.api
FlinkTopology translates a TopologyBuilder to a Flink program.
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
 
FlinkYarnClient - Class in org.apache.flink.yarn
Default implementation of FlinkYarnClientBase which starts an ApplicationMaster.
FlinkYarnClient() - Constructor for class org.apache.flink.yarn.FlinkYarnClient
 
FlinkYarnClientBase - Class in org.apache.flink.yarn
All classes in this package contain code taken from https://github.com/apache/hadoop-common/blob/trunk/hadoop-yarn-project/hadoop-yarn/hadoop-yarn-applications/hadoop-yarn-applications-distributedshell/src/main/java/org/apache/hadoop/yarn/applications/distributedshell/Client.java?source=cc and https://github.com/hortonworks/simple-yarn-app and https://github.com/yahoo/storm-yarn/blob/master/src/main/java/com/yahoo/storm/yarn/StormOnYarn.java The Flink jar is uploaded to HDFS by this client.
FlinkYarnClientBase() - Constructor for class org.apache.flink.yarn.FlinkYarnClientBase
 
FlinkYarnClientBase.YarnDeploymentException - Exception in org.apache.flink.yarn
 
FlinkYarnCluster - Class in org.apache.flink.yarn
Java representation of a running Flink cluster within YARN.
FlinkYarnCluster(YarnClient, ApplicationId, Configuration, Configuration, Path, boolean) - Constructor for class org.apache.flink.yarn.FlinkYarnCluster
Create a new Flink on YARN cluster.
FlinkYarnCluster.ClientShutdownHook - Class in org.apache.flink.yarn
 
FlinkYarnCluster.PollingThread - Class in org.apache.flink.yarn
 
FlinkYarnClusterStatus - Class in org.apache.flink.runtime.yarn
Simple status representation of a running YARN cluster.
FlinkYarnClusterStatus() - Constructor for class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
 
FlinkYarnClusterStatus(int, int) - Constructor for class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
 
FlinkYarnSessionCli - Class in org.apache.flink.client
Class handling the command line interface to the YARN session.
FlinkYarnSessionCli(String, String) - Constructor for class org.apache.flink.client.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
 
flipVertices() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
float2Literal(float) - Method in interface org.apache.flink.api.scala.table.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
 
FloatComparator - Class in org.apache.flink.api.common.typeutils.base
 
FloatComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.FloatComparator
 
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
 
FloatSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.FloatSum
 
FloatSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
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.
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
 
FlumeSink<IN> - Class in org.apache.flink.streaming.connectors.flume
 
FlumeSink(String, int, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.flume.FlumeSink
 
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
 
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.FsStateBackend.FsCheckpointStateOutputStream
 
flush() - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
flush() - Method in class org.apache.flink.streaming.connectors.fs.StringWriter
 
flush() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
Flushes out any internally held data.
flush() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
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
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
 
fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given fold function to each window.
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given fold function to each window.
fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies a fold transformation on the grouped data stream grouped on by the given key position.
fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given fold function to each window.
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given fold function to each window.
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given fold function to each window.
fold(R, Function2<R, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given fold function to each window.
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
Creates a new DataStream by folding the elements of this DataStream using an associative fold function and an initial value.
fold(R, Function2<R, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Creates a new DataStream by folding the elements of this DataStream using an associative fold function and an initial value.
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given fold function to each window.
fold(R, Function2<R, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given fold function to each window.
FoldApplyAllWindowFunction<W extends Window,T,ACC> - Class in org.apache.flink.streaming.api.functions.windowing
 
FoldApplyAllWindowFunction(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, ACC, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
 
FoldApplyWindowFunction<K,W extends Window,T,ACC> - Class in org.apache.flink.streaming.api.functions.windowing
 
FoldApplyWindowFunction(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, ACC, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
 
FoldFunction<O,T> - Interface in org.apache.flink.api.common.functions
Base interface for Fold functions.
FoldingState<T,ACC> - Interface in org.apache.flink.api.common.state
State interface for folding state.
FoldingStateDescriptor<T,ACC> - Class in org.apache.flink.api.common.state
FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, Class<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
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
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
Creates a new ValueStateDescriptor with the given name and default value.
FoldingWindowBuffer<T,ACC> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
An WindowBuffer that stores elements on the Java Heap.
FoldingWindowBuffer(FoldFunction<T, ACC>, ACC, TypeSerializer<ACC>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
 
FoldingWindowBuffer(FoldFunction<T, ACC>, StreamRecord<ACC>, TypeSerializer<ACC>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
 
FoldingWindowBuffer.Factory<T,ACC> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
 
followedBy(String) - Method in class org.apache.flink.cep.pattern.Pattern
Appends a new pattern operator to the existing one.
FollowedByPattern<T,F extends T> - Class in org.apache.flink.cep.pattern
Pattern operator which signifies that the there is a non-strict temporal contiguity between itself and its preceding pattern operator.
forGrouping(FieldList) - Static method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
ForkableFlinkMiniCluster - Class in org.apache.flink.test.util
A forkable mini cluster is a special case of the mini cluster, used for parallel test execution on build servers.
ForkableFlinkMiniCluster(Configuration, boolean) - Constructor for class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
ForkableFlinkMiniCluster(Configuration) - Constructor for class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
ForkableFlinkMiniCluster$ - Class in org.apache.flink.test.util
 
ForkableFlinkMiniCluster$() - Constructor for class org.apache.flink.test.util.ForkableFlinkMiniCluster$
 
format(IN) - Method in interface org.apache.flink.api.java.io.TextOutputFormat.TextFormatter
 
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
 
format(LoggingEvent) - Method in class org.apache.flink.util.MavenForkNumberPrefixLayout
 
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
 
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
 
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
 
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
 
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.
freshName(String) - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
freshName(String) - Method in class org.apache.flink.api.table.expressions.Expression$
 
freshName(String) - Static method in class org.apache.flink.api.table.expressions.Expression
 
freshNameCounter() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
freshNameCounter() - Method in class org.apache.flink.api.table.expressions.Expression$
 
freshNameCounter() - Static method in class org.apache.flink.api.table.expressions.Expression
 
from - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
from(IntermediateResultPartition) - Static method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
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
 
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.RecoveryMode
Return the configured RecoveryMode.
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<T>, String) - Method in class org.apache.flink.api.java.table.TableEnvironment
Transforms the given DataSet to a Table.
fromDataSet(DataSet<T>) - Method in class org.apache.flink.api.java.table.TableEnvironment
Transforms the given DataSet to a Table.
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.
fromDataStream(DataStream<T>, String) - Method in class org.apache.flink.api.java.table.TableEnvironment
Transforms the given DataStream to a Table.
fromDataStream(DataStream<T>) - Method in class org.apache.flink.api.java.table.TableEnvironment
Transforms the given DataStream to a Table.
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) - 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(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(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
 
fromGenericOptionsParser(String[]) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the arguments parsed by GenericOptionsParser
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
 
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
Returns a dummy object for wrapping a JobSubmissionResult
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
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
 
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.
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.FsStateBackend.FsCheckpointStateOutputStream
 
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
 
FSDataOutputStream - Class in org.apache.flink.core.fs
Interface for a data output stream to a file on a FileSystem.
FSDataOutputStream() - Constructor for class org.apache.flink.core.fs.FSDataOutputStream
 
FsFoldingState<K,N,T,ACC> - Class in org.apache.flink.runtime.state.filesystem
Heap-backed partitioned FoldingState that is snapshotted into files.
FsFoldingState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Constructor for class org.apache.flink.runtime.state.filesystem.FsFoldingState
Creates a new and empty partitioned state.
FsFoldingState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, FoldingStateDescriptor<T, ACC>, HashMap<N, Map<K, ACC>>) - Constructor for class org.apache.flink.runtime.state.filesystem.FsFoldingState
Creates a new key/value state with the given state contents.
FsFoldingState.Snapshot<K,N,T,ACC> - Class in org.apache.flink.runtime.state.filesystem
 
FSKey(String, String) - Constructor for class org.apache.flink.core.fs.FileSystem.FSKey
Creates a file system key from a given scheme and an authority.
FsListState<K,N,V> - Class in org.apache.flink.runtime.state.filesystem
Heap-backed partitioned ListState that is snapshotted into files.
FsListState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, ListStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.filesystem.FsListState
Creates a new and empty partitioned state.
FsListState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, ListStateDescriptor<V>, HashMap<N, Map<K, ArrayList<V>>>) - Constructor for class org.apache.flink.runtime.state.filesystem.FsListState
Creates a new key/value state with the given state contents.
FsListState.Snapshot<K,N,V> - Class in org.apache.flink.runtime.state.filesystem
 
FsReducingState<K,N,V> - Class in org.apache.flink.runtime.state.filesystem
Heap-backed partitioned ReducingState that is snapshotted into files.
FsReducingState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, ReducingStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.filesystem.FsReducingState
Creates a new and empty partitioned state.
FsReducingState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, ReducingStateDescriptor<V>, HashMap<N, Map<K, V>>) - Constructor for class org.apache.flink.runtime.state.filesystem.FsReducingState
Creates a new key/value state with the given state contents.
FsReducingState.Snapshot<K,N,V> - Class in org.apache.flink.runtime.state.filesystem
 
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(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(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, 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.FsCheckpointStateOutputStream - Class in org.apache.flink.runtime.state.filesystem
A CheckpointStateOutputStream that writes into a file and returns the path to that file upon closing.
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.runtime.state.filesystem
Heap-backed partitioned ValueState that is snapshotted into files.
FsValueState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, ValueStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.filesystem.FsValueState
Creates a new and empty key/value state.
FsValueState(FsStateBackend, TypeSerializer<K>, TypeSerializer<N>, ValueStateDescriptor<V>, HashMap<N, Map<K, V>>) - Constructor for class org.apache.flink.runtime.state.filesystem.FsValueState
Creates a new key/value state with the given state contents.
FsValueState.Snapshot<K,N,V> - Class in org.apache.flink.runtime.state.filesystem
 
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>) - 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.
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
 
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
 
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.
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
 
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

G

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.
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
 
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.
genCarStream() - Method in class org.apache.flink.examples.scala.StreamingTableFilter$
 
genCarStream() - Static method in class org.apache.flink.examples.scala.StreamingTableFilter
 
genCarStream() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing$
 
genCarStream() - Static method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing
 
generate() - Static method in class org.apache.flink.api.common.JobID
Creates a new (statistically) random JobID.
generate() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
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.
generateConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
generateConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
generateConfiguration(Configuration) - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
generateConfigurationFile(String, String, String, int, int, int, int, String) - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
GeneratedExpression(String, String, String) - Constructor for class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.GeneratedExpression
 
generateExpression(Expression) - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
generateExpressionInternal(Expression) - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
GenerateFilter<T> - Class in org.apache.flink.api.table.codegen
Code generator for a unary predicate, i.e.
GenerateFilter(CompositeType<T>, Expression, ClassLoader, TableConfig) - Constructor for class org.apache.flink.api.table.codegen.GenerateFilter
 
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
 
generateInternal() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
generateInternal() - Method in class org.apache.flink.api.table.codegen.GenerateFilter
 
generateInternal() - Method in class org.apache.flink.api.table.codegen.GenerateJoin
 
generateInternal() - Method in class org.apache.flink.api.table.codegen.GenerateSelect
 
GenerateJoin<L,R,O> - Class in org.apache.flink.api.table.codegen
Code generator for assembling the result of a binary operation.
GenerateJoin(CompositeType<L>, CompositeType<R>, CompositeType<O>, Expression, Seq<Expression>, ClassLoader, TableConfig) - Constructor for class org.apache.flink.api.table.codegen.GenerateJoin
 
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
 
GenerateResultAssembler<R> - Class in org.apache.flink.api.table.codegen
Base class for unary and binary result assembler code generators.
GenerateResultAssembler(Seq<Tuple2<String, CompositeType<?>>>, ClassLoader, TableConfig) - Constructor for class org.apache.flink.api.table.codegen.GenerateResultAssembler
 
GenerateSelect<I,O> - Class in org.apache.flink.api.table.codegen
Code generator for assembling the result of a select operation.
GenerateSelect(CompositeType<I>, CompositeType<O>, Seq<Expression>, ClassLoader, TableConfig) - Constructor for class org.apache.flink.api.table.codegen.GenerateSelect
 
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.
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
 
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
 
GenericFoldingState<K,N,T,ACC,Backend extends AbstractStateBackend,W extends ValueState<ACC> & KvState<K,N,ValueState<ACC>,ValueStateDescriptor<ACC>,Backend>> - Class in org.apache.flink.runtime.state
Generic implementation of FoldingState based on a wrapped ValueState.
GenericFoldingState(ValueState<ACC>, FoldFunction<T, ACC>) - Constructor for class org.apache.flink.runtime.state.GenericFoldingState
Creates a new FoldingState that wraps the given ValueState.
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.
GenericListState<K,N,T,Backend extends AbstractStateBackend,W extends ValueState<ArrayList<T>> & KvState<K,N,ValueState<ArrayList<T>>,ValueStateDescriptor<ArrayList<T>>,Backend>> - Class in org.apache.flink.runtime.state
Generic implementation of ListState based on a wrapped ValueState.
GenericListState(ValueState<ArrayList<T>>) - Constructor for class org.apache.flink.runtime.state.GenericListState
Creates a new ListState that wraps the given ValueState.
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$
 
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
 
GenericReducingState<K,N,T,Backend extends AbstractStateBackend,W extends ValueState<T> & KvState<K,N,ValueState<T>,ValueStateDescriptor<T>,Backend>> - Class in org.apache.flink.runtime.state
Generic implementation of ReducingState based on a wrapped ValueState.
GenericReducingState(ValueState<T>, ReduceFunction<T>) - Constructor for class org.apache.flink.runtime.state.GenericReducingState
Creates a new ReducingState that wraps the given ValueState.
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
 
get(int) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
get() - Method in interface org.apache.flink.api.common.state.MergingState
Returns the current value for the state.
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.contrib.streaming.state.RocksDBFoldingState
 
get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
 
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(Parameter<T>) - Method in class org.apache.flink.ml.common.ParameterMap
Retrieves a parameter value associated to a given key.
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(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
blocking retrieval and removal of the object to share
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() - Method in class org.apache.flink.runtime.state.filesystem.FsFoldingState
 
get() - Method in class org.apache.flink.runtime.state.filesystem.FsListState
 
get() - Method in class org.apache.flink.runtime.state.filesystem.FsReducingState
 
get() - Method in class org.apache.flink.runtime.state.GenericFoldingState
 
get() - Method in class org.apache.flink.runtime.state.GenericListState
 
get() - Method in class org.apache.flink.runtime.state.GenericReducingState
 
get() - Method in class org.apache.flink.runtime.state.memory.MemFoldingState
 
get() - Method in class org.apache.flink.runtime.state.memory.MemListState
 
get() - Method in class org.apache.flink.runtime.state.memory.MemReducingState
 
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(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
get(Throwable, ClassLoader) - Static method in exception org.apache.flink.runtime.util.SerializedThrowable
 
get(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets a state handle from ZooKeeper.
get(Object) - Method in class org.apache.flink.storm.util.StormConfig
 
get() - Static method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
get(String, String) - Method in class org.apache.flink.streaming.connectors.json.JSONParseFlatMap
Get the value object associated with a key form a JSON code.
get(K) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Looks up the value mapped under the given key.
get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.ArrayFieldAccessor
 
get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor
 
get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.PojoFieldAccessor
 
get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.ProductFieldAccessor
 
get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.SimpleFieldAccessor
 
get(R) - Method in class org.apache.flink.streaming.util.FieldAccessor.TupleFieldAccessor
 
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
 
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
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
 
getAccumulatedRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
Returns the accumulated record count.
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
 
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 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.Client
Requests and returns the accumulators for the given job identifier.
getAccumulators(JobID, ClassLoader) - Method in class org.apache.flink.client.program.Client
Requests and returns the accumulators for the given job identifier.
getAccumulators() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
Gets flink and user-defined accumulators in serialized form.
getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets a serialized accumulator map.
getAcknowledge() - Method in class org.apache.flink.runtime.messages.Messages$
Accessor for the case object instance, to simplify Java interoperability.
getAcknowledge() - Static method in class org.apache.flink.runtime.messages.Messages
Accessor for the case object instance, to simplify Java interoperability.
getAction() - Method in class org.apache.flink.cep.nfa.StateTransition
 
getActorGateway() - Method in class org.apache.flink.runtime.instance.Instance
Returns the InstanceGateway of this Instance.
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.
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 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.util.LeaderConnectionInfo
 
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
 
getAggregatedMetricAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getAggregateJobVertexState(int[], int) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
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 class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getAggregations() - Method in class org.apache.flink.api.table.expressions.Aggregation
 
getAggregations() - Method in class org.apache.flink.api.table.expressions.Avg
 
getAggregations() - Method in class org.apache.flink.api.table.expressions.Count
 
getAggregations() - Method in class org.apache.flink.api.table.expressions.Max
 
getAggregations() - Method in class org.apache.flink.api.table.expressions.Min
 
getAggregations() - Method in class org.apache.flink.api.table.expressions.Sum
 
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, Option<Tuple2<String, Object>>) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Creates an akka config with the provided 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.
getAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets all available state handles from ZooKeeper.
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
 
getAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns all CompletedCheckpoint instances.
getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getAllDeclaredFields(Class<?>) - 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.
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
 
getAllNodes() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
Gets all the nodes from this OptimizedPlan.
getAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getAllowQueuedScheduling() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
getAllRegisteredAggregators() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getAllRegisteredInstances() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getAllSortedByName() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets all available state handles from ZooKeeper sorted by name (ascending).
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
 
getAndCheckJobManagerAddress(Configuration) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Gets the hostname and port of the JobManager from the configuration.
getAndCheckJobManagerAddress(Configuration) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Gets the hostname and port of the JobManager from the configuration.
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
 
getAndIncrementCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getAndRemove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
blocking retrieval and removal of the object to share
getAppId() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getApplicationId() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Returns a string representation of the ApplicationID assigned by YARN.
getApplicationId() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
getApplicationMasterClass() - Method in class org.apache.flink.yarn.FlinkYarnClient
 
getApplicationMasterClass() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
getApplyBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Get the broadcast variables of the ApplyFunction.
getArchiveName(int) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getArchivistClass() - Method in class org.apache.flink.yarn.ApplicationMaster
 
getArchivistClass() - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
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
 
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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
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
 
getAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
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 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
 
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.
getAverageDuration() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
Returns the average checkpoint duration ever seen over all completed checkpoints.
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.
getAverageStateSize() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
Average the minimum checkpoint state size ever seen over all completed checkpoints.
getAvgOutputRecordSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
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
 
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.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<?>, boolean, boolean, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the binary operator's return type.
getBinaryOperatorReturnType(Function, Class<?>, 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.
getBitSize(long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
 
getBlobServerPort() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
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
 
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(String, boolean) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Returns the value associated with the given key as a boolean.
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.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
getBoolean(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getBoolean(String, String) - Method in class org.apache.flink.streaming.connectors.json.JSONParseFlatMap
Get the boolean value associated with a key form a JSON code.
getBooleanByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
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.spargel.MessagingFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
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.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.
getBucketBoundary(int, int) - Method in class org.apache.flink.api.common.distributions.SimpleDistribution
 
getBucketBoundary(int, int) - Method in class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
 
getBucketBoundary(int, int) - Method in class org.apache.flink.api.common.distributions.UniformDoubleDistribution
 
getBucketBoundary(int, int) - Method in class org.apache.flink.api.common.distributions.UniformIntegerDistribution
 
getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
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
Sets 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
 
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.runtime.util.DataOutputSerializer
 
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() - Method in class org.apache.flink.contrib.streaming.state.DbStateHandle
 
getBytes(String, byte[]) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
getBytes() - Method in class org.apache.flink.util.AbstractID
Gets the bytes underlying this ID.
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.
getCachedFiles() - Method in class org.apache.flink.api.common.Plan
return the registered caches files
getCallLocationName() - Static method in class org.apache.flink.api.java.Utils
 
getCallLocationName(int) - Static method in class org.apache.flink.api.java.Utils
 
getCandidateAtBranchPoint(OptimizerNode) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
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
 
getCause() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
getCauseAsString() - Method in exception org.apache.flink.runtime.io.network.partition.ProducerFailedException
Returns the stringified cause of the producer failure.
getCbf() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
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
 
getChainingStrategy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
 
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.
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
 
getCheckpoint(String, Connection, long, long, long) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Retrieve the serialized checkpoint data from the database.
getCheckpoint(String, Connection, long, long, long) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
getCheckpointBarrierListener() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
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 class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets the directory where this state backend stores its checkpoint data.
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.stats.CheckpointStats
Returns the ID of the checkpoint.
getCheckpointId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getCheckpointId() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
Gets the checkpointId of the checkpoint.
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
 
getCheckpointInterval() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
 
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.api.operators.StreamSource.AutomaticWatermarkContext
 
getCheckpointLock() - Method in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
 
getCheckpointLock() - Method in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
 
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.
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
getCheckpointStatsTracker() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointTimeout() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
 
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
 
getChecksum() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
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.
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.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
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
 
getCleanUpInterval() - Method in class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Cleanup interval for completed stats cache.
getClient(CommandLineOptions, String, int, boolean) - Method in class org.apache.flink.client.CliFrontend
Retrieves a Client object from the given command line options and other parameters.
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
 
getClientConnectTimeoutSeconds() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getClientNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getClientTimeout(Configuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getClientTimeout(Configuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getClosedBranchingNodes() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getClusterDescription() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
Returns a String containing details about the cluster (NodeManagers, available memory, ...)
getClusterDescription() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
getClusterInfo() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
getClusterStatus() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Returns the latest cluster status, with number of Taskmanagers and slots
getClusterStatus() - Method in class org.apache.flink.yarn.FlinkYarnCluster
This method is only available if the cluster hasn't been started in detached mode.
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
 
getCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
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
 
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
 
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.
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
 
getCompiler_hints() - Method in class org.apache.flink.api.table.explain.Node
 
getCompilerHints() - Method in class org.apache.flink.api.common.operators.Operator
Gets the compiler hints for this contract instance.
getComponentClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Gets the class that represents the component type.
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.
getComponentTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getCondition() - Method in class org.apache.flink.cep.nfa.StateTransition
 
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.
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() - Static method in class org.apache.flink.configuration.GlobalConfiguration
Gets a Configuration object with the values of this GlobalConfiguration
getConfiguration() - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
Get the backend configuration object.
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.operators.util.TaskConfig
Gets the configuration that holds the actual values encoded.
getConfiguration() - Method in class 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.
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
 
getConnections() - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
Get the database connections maintained by the backend.
getConnectionTimeout() - Method in class org.apache.flink.runtime.messages.JobClientMessages$
 
getConnectionTimeout() - Static method in class org.apache.flink.runtime.messages.JobClientMessages
 
getConsumedPartitionId() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
getConsumedPartitionLocation() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
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
 
getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
getContainerMapping() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getContainersFromPreviousAttempts(RegisterApplicationMasterResponse) - Method in class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector$
 
getContainersFromPreviousAttempts(RegisterApplicationMasterResponse) - Static method in class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector
 
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.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.api.table.explain.Node
 
getContext() - Method in class org.apache.flink.graph.Graph
 
getContributors() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
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
 
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.
getCosts() - Method in class org.apache.flink.api.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 interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
Returns the total number of completed checkpoints.
getCountDbitmap() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
getCountDlog2m() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
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
 
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
 
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
 
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.NumberSequenceIterator
 
getCurrentAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
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
 
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.
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.AbstractStateBackend
 
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
 
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
 
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
 
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 class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
 
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 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.NonKeyedWindowOperator.Context
 
getCurrentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
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
 
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.python.api.types.CustomTypeWrapper
 
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.
getDataSet() - Method in class org.apache.flink.api.java.operators.DataSink
 
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.
getDataType() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
getDataType() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
getDbAdapter() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Get the DbAdapter that will be used to operate on the database during checkpointing.
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
 
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.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
 
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.JaccardSimilarityMeasureData
 
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
 
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.
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
 
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
 
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.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
 
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
getDelayBetweenAttempts() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getDelimiter() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
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.
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.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.examples.java.graph.ConnectedComponents
 
getDescription() - Method in class org.apache.flink.examples.java.graph.TransitiveClosureNaive
 
getDescription() - Method in class org.apache.flink.graph.examples.ConnectedComponents
 
getDescription() - Method in class org.apache.flink.graph.examples.EuclideanGraphWeighing
 
getDescription() - Method in class org.apache.flink.graph.examples.GraphMetrics
 
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.JaccardSimilarityMeasure
 
getDescription() - Method in class org.apache.flink.graph.examples.MusicProfiles
 
getDescription() - Method in class org.apache.flink.graph.examples.SingleSourceShortestPaths
 
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
 
getDetachedMode() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getDiagnostics() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
 
getDiagnostics() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
getDiffUrl() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
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.MessagingFunction
Retrieves the edge direction in which messages are propagated in the vertex-centric iteration.
getDirection() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Gets the direction in which messages are sent in the MessagingFunction.
getDirections(Ordering, int) - Static method in class org.apache.flink.optimizer.util.Utils
 
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
 
getDisposeSavepointPath() - Method in class org.apache.flink.client.cli.SavepointOptions
 
getDisposeSavepointSuccess() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getDisposeSavepointSuccess() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
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
 
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(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.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
getDouble(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getDouble(String, String) - Method in class org.apache.flink.streaming.connectors.json.JSONParseFlatMap
Get the double value associated with a key form a JSON code.
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.api.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
 
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.runtime.checkpoint.CompletedCheckpoint
 
getDuration() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
 
getDuration() - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
Returns the duration in milliseconds.
getDynamicProperties(String) - Static method in class org.apache.flink.client.CliFrontend
 
getDynamicPropertiesEncoded() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
getDynamicPropertiesEncoded() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
getEagerlyDeployConsumers() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
Returns whether consumers should be deployed eagerly (as soon as they are registered at the result manager of the task manager).
getEagerlyDeployConsumers() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getEagerlyDeployConsumers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Returns whether consumers should be deployed eagerly (as soon as they are registered at the result manager of the task manager).
getEagerlyDeployConsumers() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
Returns whether consumers should be deployed eagerly (as soon as they are registered at the result manager of the task manager).
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(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.scala.Graph
 
getEdges() - Method in class org.apache.flink.graph.spargel.MessagingFunction
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
 
getEdgesWithAbsentValues(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.SummarizationData
Creates a set of edges with NullValue as edge value.
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.
getElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
 
getElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
 
getElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
 
getElements() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
Returns all elements that are currently in the buffer.
getElementsCollectedAndReset() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
getEnd() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
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.
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
 
getEntryPointClassName() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getEnumeratingVertices(int) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
 
getEnvironment() - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
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(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.api.table.explain.Node
 
getEvent() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperator
 
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
 
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 class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the global ExecutionConfig, obtained from the job configuration.
getExecutionConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
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.executiongraph.ExecutionGraph
Returns the ExecutionContext associated with this ExecutionGraph.
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() - 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 class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
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.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 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.contrib.streaming.state.LazyDbValueState
Used for testing purposes
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
 
getExtendedprice() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
 
getExternalJars() - Method in class org.apache.flink.api.scala.FlinkILoop
 
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.
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.
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.
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(scala.reflect.runtime.universe, CompositeType<?>, String, TypeInformation<?>) - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
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.
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.TupleTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
getFieldIndices(String[]) - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getFieldInto(int, Value) - Method in class org.apache.flink.types.Record
Gets the field at the given position.
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.TupleTypeInfo
 
getFieldNames() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getFieldNames() - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
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
 
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
 
getFieldType() - Method in class org.apache.flink.streaming.util.FieldAccessor
 
getFieldTypes() - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
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.runtime.fs.hdfs.HadoopFileSystem
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
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.runtime.state.filesystem.AbstractFileStateHandle
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.runtime.state.filesystem.AbstractFileStateHandle
Returns the file size in bytes.
getFileStateSizeThreshold() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets the size (in bytes) above which the state will written to files.
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.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.runtime.state.filesystem.AbstractFileStateHandle
Gets the file system that stores the file state.
getFileSystem() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets the file system handle for the file system that stores the state for this backend.
getFilter_level() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getFilterFactor() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getFilterFunction() - Method in class org.apache.flink.cep.pattern.Pattern
 
getFinalField(Seq<Expression>) - Method in class org.apache.flink.api.table.expressions.Aggregation
 
getFinalField(Seq<Expression>) - Method in class org.apache.flink.api.table.expressions.Avg
 
getFinalField(Seq<Expression>) - Method in class org.apache.flink.api.table.expressions.Count
 
getFinalField(Seq<Expression>) - Method in class org.apache.flink.api.table.expressions.Max
 
getFinalField(Seq<Expression>) - Method in class org.apache.flink.api.table.expressions.Min
 
getFinalField(Seq<Expression>) - Method in class org.apache.flink.api.table.expressions.Sum
 
getFinishedJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
getFirst() - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
getFirst() - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection.ShardedStatement
 
getFirst() - Method in class org.apache.flink.types.Pair
Returns the first encapsulated pair element.
getFirstDegree() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
getFirstDegree() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
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
 
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.TupleComparatorBase
 
getFlatComparator(List<TypeComparator<?>>) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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.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.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.table.typeinfo.NullAwareComparator
 
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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
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
 
getFlinkAccumulators() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getFlinkAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the internal flink accumulator map of maps which contains some metrics.
getFlinkConfiguration() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
getFlinkConfiguration() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Return the Flink configuration object
getFlinkConfiguration() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
getFlinkConfiguration() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
getFlinkLoggingConfigurationPath() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
getFlinkLoggingConfigurationPath() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
getFlinkYarnClient() - Static method in class org.apache.flink.client.FlinkYarnSessionCli
 
getFlinkYarnSessionCli() - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
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(String, float) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Returns the value associated with the given key as a float.
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.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
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
Returns the fold function to be used for the folding state.
getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFollowers_count() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getFollowings() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function tells which users are followed.
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
 
getForIndex(int) - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
getForIndex(int) - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection.ShardedStatement
 
getForKey(Object) - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
getForKey(Object) - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection.ShardedStatement
 
getFormat() - Method in class org.apache.flink.api.java.operators.DataSink
 
getFormat() - Method in class org.apache.flink.streaming.api.functions.source.FileSourceFunction
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.instance.InstanceConnectionInfo
Returns the fully-qualified domain name the TaskManager.
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
 
getFreeSlotForTask(ExecutionVertex, Iterable<Instance>, 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
 
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
 
getFunctionName() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
getFunctionState() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
 
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.
getGenericFieldTypes() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getGenericParameters() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Returns the generic parameters of this type.
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.api.table.typeinfo.RenamingProxyTypeInfo
 
getGlobal_properties() - Method in class org.apache.flink.api.table.explain.Node
 
getGlobalJobParameters() - Method in class org.apache.flink.api.common.ExecutionConfig
 
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.
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
 
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.
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
 
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
 
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
 
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).
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.
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
 
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
 
getHeadOutput() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getHeavyHitterConfidence() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
getHeavyHitterError() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
getHeavyHitterFraction() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
getHeavyHitters() - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.CountMinHeavyHitter
 
getHeavyHitters() - Method in interface org.apache.flink.contrib.operatorstatistics.heavyhitters.HeavyHitter
 
getHeavyHitters() - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.LossyCounting
 
getHeavyHitters() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatistics
 
getHeavyHitterSeed() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
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
 
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.runtime.fs.hdfs.HadoopFileSystem
 
getHomeDirectory() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getHost() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getHost() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Gets the hostname of the master (JobManager), where the program will be executed.
getHostname() - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
Gets the hostname of the TaskManager.
getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Gets host name of the interface that the TaskManager uses to communicate.
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
 
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 class org.apache.flink.api.table.explain.Node
 
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() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the unique ID of this StreamTransformation.
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
 
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.
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
 
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.spargel.MessagingFunction
Retrieves the vertex in-degree (number of in-coming edges).
getInDegree() - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
Retrieves the vertex in-degree (number of in-coming edges).
getindent(String) - Method in class org.apache.flink.api.table.codegen.IndentStringContext
 
getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the task's index in the subtask group.
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.
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
 
getInetAdress() - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
Gets the IP address where the TaskManager operates.
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.
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<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
 
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
 
getInPhysicalEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
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.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.SinkTransformation
Returns the input StreamTransformation of this SinkTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
Returns the input StreamTransformation.
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.
getInputChannelDeploymentDescriptors() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
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.
getInputSerializer() - Method in class org.apache.flink.cep.operator.AbstractCEPPatternOperator
 
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.TableInputFormat
 
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(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
 
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
 
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
 
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() - Method in exception org.apache.flink.runtime.instance.InstanceDiedException
 
getInstance() - Method in class org.apache.flink.runtime.instance.Slot
Gets the instance from which the slot was allocated.
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.types.NullValue
Returns the NullValue singleton instance.
getInstanceConnectionInfo() - Method in class org.apache.flink.runtime.instance.Instance
 
getInstancesByHost() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
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(String, String) - Method in class org.apache.flink.streaming.connectors.json.JSONParseFlatMap
Get the int value associated with a key form a JSON code.
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.
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(String, int) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Returns the value associated with the given key as an integer.
getInteger(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
getInteger(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getIntegerByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
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.
getIntermediateFields() - Method in class org.apache.flink.api.table.expressions.Aggregation
 
getIntermediateFields() - Method in class org.apache.flink.api.table.expressions.Avg
 
getIntermediateFields() - Method in class org.apache.flink.api.table.expressions.Count
 
getIntermediateFields() - Method in class org.apache.flink.api.table.expressions.Max
 
getIntermediateFields() - Method in class org.apache.flink.api.table.expressions.Min
 
getIntermediateFields() - Method in class org.apache.flink.api.table.expressions.Sum
 
getIntermediateResult() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getInternalFileStatus() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
getInternalUdfClassName() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
getIntFromConfig(Properties, String, int) - Static method in class org.apache.flink.streaming.connectors.kafka.util.KafkaUtils
 
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.
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.deployment.TaskDeploymentDescriptor
Returns the name of the class containing the task code to be executed.
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
 
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.taskmanager.RuntimeEnvironment
 
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.spargel.MessagingFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
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.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.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
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
 
getJarFilePath() - Method in class org.apache.flink.client.cli.ProgramOptions
 
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
 
getJavaEnv() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
 
getJDBCDriver() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The class name that should be used to load the JDBC driver using Class.forName(JDBCDriverClass).
getJob() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
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 class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the configuration of the job the task belongs to.
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.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
 
getJobGraph(PackagedProgram, FlinkPlan) - Method in class org.apache.flink.client.program.Client
 
getJobGraph(PackagedProgram, FlinkPlan, String) - Method in class org.apache.flink.client.program.Client
 
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(Map<String, String>, Map<String, String>) - 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.JobStatusMessage
 
getJobId() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
getJobID() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the ID of the job the tasks belongs to.
getJobID() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the ID of the job that the task belongs to.
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.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.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.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
getJobInfo() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the JobInfo of the client who submitted the JobGraph.
getJobManagerActorRef(String, ActorSystem, FiniteDuration) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Resolves the JobManager actor reference in a blocking fashion.
getJobManagerActorRef(InetSocketAddress, ActorSystem, FiniteDuration) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Resolves the JobManager actor reference in a blocking fashion.
getJobManagerActorRef(InetSocketAddress, ActorSystem, Configuration) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Resolves the JobManager actor reference in a blocking fashion.
getJobManagerActorRef(String, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Resolves the JobManager actor reference in a blocking fashion.
getJobManagerActorRef(InetSocketAddress, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Resolves the JobManager actor reference in a blocking fashion.
getJobManagerActorRef(InetSocketAddress, ActorSystem, Configuration) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Resolves the JobManager actor reference in a blocking fashion.
getJobManagerActorRefFuture(InetSocketAddress, ActorSystem, FiniteDuration) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
 
getJobManagerActorRefFuture(InetSocketAddress, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
getJobManagerAddress() - Method in class org.apache.flink.client.cli.CommandLineOptions
 
getJobManagerAddress() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Get hostname and port of the JobManager.
getJobManagerAddress() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
getJobManagerAkkaConfig(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getJobManagerAkkaURL(ActorSystem, Option<String>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
 
getJobManagerAkkaURL(ActorSystem, Option<String>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
getJobManagerClass() - Method in class org.apache.flink.yarn.ApplicationMaster
 
getJobManagerClass() - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
getJobManagerGateway(CommandLineOptions) - Method in class org.apache.flink.client.CliFrontend
Retrieves the ActorGateway for the JobManager.
getJobManagerGatewayAndWebPort() - Method in class org.apache.flink.runtime.webmonitor.JobManagerRetriever
Returns the currently known leading job manager gateway and its web monitor port.
getJobManagerMode() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getJobManagerName(int) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
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
 
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 class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobName() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getJobName() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getJobsCancelled() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
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
 
getJobStats() - Method in interface org.apache.flink.runtime.checkpoint.stats.CheckpointStatsTracker
Returns a snapshot of the checkpoint statistics for a job.
getJobStats() - Method in class org.apache.flink.runtime.checkpoint.stats.DisabledCheckpointStatsTracker
 
getJobStats() - Method in class org.apache.flink.runtime.checkpoint.stats.SimpleCheckpointStatsTracker
 
getJobStatusListener() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
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 interface org.apache.flink.runtime.execution.Environment
Gets the ID of the JobVertex for which this task executes a parallel subtask.
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.jobmanager.scheduler.ScheduledUnit
 
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.
getJSON() - Method in class org.apache.flink.streaming.api.graph.JSONGenerator
 
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".
getKey(IN) - Method in interface org.apache.flink.api.java.functions.KeySelector
User-defined function that extracts the key from an arbitrary object.
getKey(IN) - Method in class org.apache.flink.streaming.api.scala.KeySelectorWithType
 
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
 
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
 
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.
getKeys(AbstractSchema<Class<? extends X>>, int[]) - Static method in class org.apache.flink.optimizer.postpass.PostPassUtils
 
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.runtime.state.AbstractHeapState
Gets the serializer for the keys.
getKeysForInput1() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getKeysForInput2() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
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.
getKeyValueState(String, Class<S>, S) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Deprecated.
Use the more expressive RuntimeContext.getState(ValueStateDescriptor) instead.
getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Deprecated.
Use the more expressive RuntimeContext.getState(ValueStateDescriptor) instead.
getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
Deprecated.
getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
Deprecated.
getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Deprecated.
getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Deprecated.
getKeyValueState(String, Class<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Deprecated.
getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Deprecated.
getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
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
 
getKryo() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
getKvCacheSize() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The maximum number of key-value pairs stored in one task instance's cache before evicting to the underlying database.
getKvStateCompactionFrequency() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Sets how often will automatic compaction be performed on the database to remove old overwritten state changes.
getKvStates() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
 
getLang() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getLang() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getLanguages() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function tells which languages are filtered.
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
 
getLastMetricsReport() - Method in class org.apache.flink.runtime.instance.Instance
 
getLastModificationTime() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the timestamp of the last modification.
getLastOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getLastReport() - Method in class org.apache.flink.yarn.FlinkYarnCluster.PollingThread
 
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.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
 
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.ZooKeeperCompletedCheckpointStore
 
getLatestExecutionResult() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
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
 
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.LocalFlinkMiniCluster
 
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.checkpoint.CheckpointCoordinatorDeActivator
 
getLeaderSessionID() - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinatorDeActivator
 
getLeaderSessionID() - Method in class org.apache.flink.runtime.client.JobClientActor
 
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
 
getLeftType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
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.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.LongSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
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.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 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.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.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.api.table.typeinfo.RowSerializer
 
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.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.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.MultiplexingStreamRecordSerializer
 
getLength() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
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 class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getLocal_properties() - Method in class org.apache.flink.api.table.explain.Node
 
getLocalCluster() - Static method in class org.apache.flink.storm.api.FlinkLocalCluster
Returns a FlinkLocalCluster that should be used for execution.
getLocalFileSystem() - Static method in class org.apache.flink.core.fs.FileSystem
Returns a reference to the FileSystem instance for accessing the local file system.
getLocalGetyarnClusterStatus() - Method in class org.apache.flink.yarn.YarnMessages$
 
getLocalGetyarnClusterStatus() - Static method in class org.apache.flink.yarn.YarnMessages
 
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.
getLocalJobManagerAkkaURL(Option<String>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Builds the akka actor path for the JobManager actor to address the actor within its own actor system.
getLocalJobManagerAkkaURL(Option<String>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Builds the akka actor path for the JobManager actor to address the actor within its own actor system.
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.Histogram
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
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.SerializedListAccumulator
 
getLocalValue() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
getLocalValue() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsAccumulator
 
getLocalValue() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
getLocalValue() - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
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
 
getLocations() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function tells which locations are filtered.
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().
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(String, long) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Returns the value associated with the given key as a long integer.
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.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
getLong(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getLong(String, String) - Method in class org.apache.flink.streaming.connectors.json.JSONParseFlatMap
Get the long value associated with a key form a JSON code.
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
 
getLongDoubleEdgeData(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.utils.ExampleUtils
 
getLongDoubleVertexData(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.utils.ExampleUtils
 
getLongFromConfig(Properties, String, long) - Static method in class org.apache.flink.streaming.connectors.kafka.util.KafkaUtils
 
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
 
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
 
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
 
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, 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
 
getMaterializationMode() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
getMax() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatistics
 
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.JobSnapshottingSettings
 
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.
getMaxDuration() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
Returns the maximum checkpoint duration ever seen over all completed checkpoints.
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
 
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.NumberSequenceIterator
 
getMaximumNumberOfSplits() - Method in class org.apache.flink.util.SplittableIterator
The maximum number of splits into which this iterator can be split up.
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.
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.
getMaxKvCacheEvictFraction() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The maximum fraction of key-value states evicted from the cache if the cache is full.
getMaxKvInsertBatchSize() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The maximum number of key-value pairs inserted in the database as one batch operation.
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
 
getMaxNumberOfSqlRetries() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The number of times each SQL command will be retried on failure.
getMaxSlots() - Method in class org.apache.flink.client.program.Client
 
getMaxStateSize() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
Returns the maximum checkpoint state size ever seen over all completed checkpoints.
getMeasurableFromKafkaMetric(KafkaMetric) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
This utility method is using reflection to get the Measurable from the KafkaMetric.
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
 
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
 
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.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.
getMessage() - Method in exception org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel.BufferReorderingException
 
getMessage() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
getMessageId() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getMessagingBcastVars() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Get the broadcast variables of the MessagingFunction.
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.contrib.operatorstatistics.OperatorStatistics
 
getMinDuration() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
Returns the minimum checkpoint duration ever seen over all completed checkpoints.
getMinimalMemoryAcrossAllSubTasks() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets the amount of memory that all subtasks of this task have jointly available.
getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
 
getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the minimal pause between checkpointing attempts.
getMinSplitSize() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getMinStateSize() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
Returns the minimum checkpoint state size ever seen over all completed checkpoints.
getMismatches(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.MusicProfilesData
 
getMissingArguments() - Method in exception org.apache.flink.api.java.utils.RequiredParametersException
 
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
 
getModified() - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
Return the Map of modified states that hasn't been written to the database yet.
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.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.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(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 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.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)".
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.AbstractHeapState
Gets the serializer for the namespace.
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.
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
 
getNetworkCost() - Method in class org.apache.flink.optimizer.costs.Costs
Gets the network cost.
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.runtime.yarn.AbstractFlinkYarnCluster
May return new messages from the cluster.
getNewMessages() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
getNewNodeId() - Static method in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
getNewSlotForSharingGroup(ExecutionVertex, Iterable<Instance>, 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
Returns the Path of a new bucket file.
getNextBucketPath(Path) - Method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
 
getNextBucketPath(Path) - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
 
getNextBuffer() - Method in class org.apache.flink.runtime.io.network.api.reader.BufferReader
 
getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
 
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
 
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(String, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex.PredeterminedInputSplitAssigner
 
getNextInputSplit() - Method in interface org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider
Requests the next input split to be consumed by the calling task.
getNextInputSplit() - 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
 
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
 
getNFA() - Method in class org.apache.flink.cep.operator.AbstractCEPPatternOperator
 
getNFA() - Method in class org.apache.flink.cep.operator.CEPPatternOperator
 
getNFA() - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
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
 
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.BooleanComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
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.EnumComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
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.PojoComparator
 
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.table.typeinfo.NullAwareComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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.
getNullCheck() - Method in class org.apache.flink.api.table.TableConfig
Returns the NULL check.
getNumberCPUCores() - Static method in class org.apache.flink.runtime.instance.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.
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
 
getNumberOfCPUCores() - Method in class org.apache.flink.runtime.instance.HardwareDescription
Returns the number of CPU cores available to the JVM on the compute node.
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
 
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(). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
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.
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.distributions.SimpleDistribution
 
getNumberOfFields() - Method in class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
 
getNumberOfFields() - Method in class org.apache.flink.api.common.distributions.UniformDoubleDistribution
 
getNumberOfFields() - Method in class org.apache.flink.api.common.distributions.UniformIntegerDistribution
 
getNumberOfFields() - Method in class org.apache.flink.api.common.operators.Ordering
 
getNumberOfFieldsTotal() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
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
 
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.
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
 
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).
getNumberOfReferenceHolders(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
getNumberOfRegisteredBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getNumberOfRegisteredTaskManagers() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
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.
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.ZooKeeperCompletedCheckpointStore
 
getNumberOfRetainedSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getNumberOfShards() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Number of database shards defined.
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.yarn.FlinkYarnClusterStatus
 
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.
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.stats.OperatorCheckpointStats
Returns the number of sub tasks.
getNumberOfSubtasks() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the current number of subtasks.
getNumberOfSubTasks() - Method in class org.apache.flink.runtime.webmonitor.OperatorBackPressureStats
Returns the number of sub tasks.
getNumberOfTaskManagers() - Method in class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
 
getNumberOfUnconstrainedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
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.spargel.MessagingFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the number of all vertices.
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.
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.
getNumElementsToEvict() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The number of elements that will be evicted when the cache is full.
getNumFields() - Method in class org.apache.flink.types.Record
Gets the number of fields currently in the record.
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
 
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
 
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
 
getNumRequiredComparators() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
getNumShards() - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
getNumSlotsAvailable() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
getNumSlotsTotal() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
getNumSplits() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
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.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
 
getNumTypes() - Method in class org.apache.flink.optimizer.postpass.SparseKeySchema
 
getNumVerticesPerExecutionState() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
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.
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.runtime.fs.hdfs.HadoopBlockLocation
 
getOffsetFromZooKeeper(CuratorFramework, String, String, int) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
 
getOffsets(List<KafkaTopicPartition>) - Method in interface org.apache.flink.streaming.connectors.kafka.internals.OffsetHandler
Positions the given fetcher to the initial read offsets where the stream consumption will start from.
getOffsets(List<KafkaTopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
 
getOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
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
 
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.
getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorDescription() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorId() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
 
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.StreamNode
 
getOperatorPrettyName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getOperators() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getOperatorState() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getOperatorState() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
 
getOperatorStats(JobVertexID) - Method in interface org.apache.flink.runtime.checkpoint.stats.CheckpointStatsTracker
Returns a snapshot of the checkpoint statistics for an operator.
getOperatorStats(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.stats.DisabledCheckpointStatsTracker
 
getOperatorStats(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.stats.SimpleCheckpointStatsTracker
 
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.Client
 
getOptimizedPlan(Optimizer, Plan, int) - Static method in class org.apache.flink.client.program.Client
 
getOptimizedPlan(PackagedProgram) - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
 
getOptimizedPlanAsJson(Optimizer, PackagedProgram, int) - Static method in class org.apache.flink.client.program.Client
 
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.
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.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
 
getOriginalCause() - Method in exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
 
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.
getOutDegree() - Method in class org.apache.flink.graph.spargel.MessagingFunction
Retrieve the vertex out-degree (number of out-going edges).
getOutDegree() - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
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, AccumulatorRegistry.Reporter) - 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
 
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.
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.
getOwningNepheleTask() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getOwningNepheleTask() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getPackages() - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
getPact() - Method in class org.apache.flink.api.table.explain.Node
 
getPactPlanAsJSON(List<DataSinkNode>) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
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
 
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() - 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.api.table.explain.Node
 
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.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.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.test.util.JavaProgramTestBase
 
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
 
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
 
getPartitionConsumableNotifier() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
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.AbstractStateBackend
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 an 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.NonKeyedWindowOperator.Context
 
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
 
getPartitionManager() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
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
 
getPartitionRequestInitialAndMaxBackoff() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
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.io.network.NetworkEnvironment
 
getPartitionType() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
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.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.
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).
getPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getPhone() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
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.
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.
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
 
getPojoFieldAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
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.streaming.api.environment.RemoteStreamEnvironment
Gets the port of the master (JobManager), where the program will be executed.
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.FSDataInputStream
Get the current position in the input stream.
getPos() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
getPos() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
getPosition() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
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.
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.api.table.explain.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.
getPredefinedOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Gets the currently set predefined options for RocksDB.
getPreferredLocations() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the location preferences of this task, determined by the locations of the predecessors from which it receives input data.
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
 
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.spargel.MessagingFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousType() - Method in exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
 
getPrintStatusDuringExecution() - Method in class org.apache.flink.client.program.Client
 
getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getPriorityQueue() - Method in class org.apache.flink.cep.operator.AbstractCEPPatternOperator
 
getPriorityQueue() - Method in class org.apache.flink.cep.operator.CEPPatternOperator
 
getPriorityQueue() - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
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
 
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
 
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.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.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.LabelPropagation.SendNewLabelToNeighbors
 
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.functions.source.ConnectorSource
 
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.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
 
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
 
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.YarnJobManager.AMRMClientAsyncHandler
 
getProperties() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns a Properties object from this ParameterTool
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
 
getQueryParameters() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function tells which query parameters are used by the endpoint.
getQueueSize() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
Get the size of the queue in which the tweets are contained temporarily.
getRandomEdges(ExecutionEnvironment, long) - Static method in class org.apache.flink.graph.examples.utils.ExampleUtils
 
getRandomFilename(String) - Static method in class org.apache.flink.runtime.util.FileUtils
Constructs a random filename with the given prefix and a random part generated from hex characters.
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
 
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).
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.
getReadWriteReporter() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
Gets the reporter for flink internal metrics.
getRecentHistory() - Method in interface org.apache.flink.runtime.checkpoint.stats.JobCheckpointStats
Returns a list of recently completed checkpoints stats.
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
getRecoverAllJobs() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRecoverAllJobs() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRecoveryTimestamp() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
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) - 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 list state.
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getRefreshInterval() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
 
getRegion() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getRegisteredAtJobManagerMessage() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages$
Accessor for the case object instance, to simplify Java interoperability.
getRegisteredAtJobManagerMessage() - Static method in class org.apache.flink.runtime.messages.TaskManagerMessages
Accessor for the case object instance, to simplify Java interoperability.
getRegisteredExecutions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getRegisteredInstance(ActorRef) - 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.
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.
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.
getRemoteJobManagerAkkaURL(InetSocketAddress, Option<String>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Builds the akka actor path for the JobManager actor, given the socket address where the JobManager's actor system runs.
getRemoteJobManagerAkkaURL(Configuration) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Returns the JobManager actor's remote Akka URL, given the configured hostname and port.
getRemoteJobManagerAkkaURL(InetSocketAddress, Option<String>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Builds the akka actor path for the JobManager actor, given the socket address where the JobManager's actor system runs.
getRemoteJobManagerAkkaURL(Configuration) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Returns the JobManager actor's remote Akka URL, given the configured hostname and port.
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.
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
 
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
 
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
 
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.deployment.TaskDeploymentDescriptor
 
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
getRequiredGlobalProps() - Method in class org.apache.flink.optimizer.plan.Channel
 
getRequiredJarFiles() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
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
getRequiredLocalProps() - Method in class org.apache.flink.optimizer.plan.Channel
 
getResize() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Size
 
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.
getRestartStrategyConfiguration() - Method in class org.apache.flink.api.common.Plan
Returns the specified restart strategy configuration.
getRestartStrategyConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Gets the restart strategy configuration
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
 
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
 
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
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.
getRightType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getRoot() - Method in class org.apache.flink.runtime.instance.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.
getRunning() - Method in class org.apache.flink.client.cli.ListOptions
 
getRunningJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
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.InternalIterableWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
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.
getSavepointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getSavepointPath() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getSavepointPath() - Method in class org.apache.flink.client.program.ContextEnvironment
 
getSavepointPath() - Method in class org.apache.flink.client.program.PackagedProgram
 
getSavepointPath() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
Returns the configured savepoint path or null if none is configured.
getSavepointRestorePath() - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
 
getScanner() - Method in class org.apache.flink.addons.hbase.TableInputFormat
 
getScheduled() - Method in class org.apache.flink.client.cli.ListOptions
 
getScheduleMode() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getScheduleMode() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
getScheduler() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
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
 
getSecond() - Method in class org.apache.flink.types.Pair
Returns the second encapsulated pair element.
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
 
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
 
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
 
getSerializedAccumulatorResults() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
getSerializedData() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
Gets the binary data for the serialized elements.
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() - 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(Object) - Static method in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
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.
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 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
 
getSessionFilesDir() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
getSessionFilesDir() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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.
getShardIndex(Object) - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
getShardIndex(Object, int) - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection.ModHashPartitioner
 
getShardIndex(Object, int) - Method in interface org.apache.flink.contrib.streaming.state.ShardedConnection.Partitioner
 
getShardUrl(int) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The url of a specific shard.
getShardUrls() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Database shard urls as provided in the constructor.
getSharedSlot() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the shared slot into which this constraint's tasks are places.
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
 
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
 
getSimpleEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.CommunityDetectionData
 
getSimpleName() - 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().
getSingleInputNode() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
getSingleInputNodeSchema(SingleInputPlanNode, T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
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.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.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.TumblingEventTimeWindows
 
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.
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() - Static method in class org.apache.flink.runtime.instance.Hardware
Returns the size of the physical memory in bytes.
getSizeOfPhysicalMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
Returns the size of physical memory in bytes available on the compute node.
getSizeOfSerializedState() - Method in class org.apache.flink.runtime.state.memory.SerializedStateHandle
Gets the size of the serialized state.
getSizeOfSerializedState() - Method in class org.apache.flink.util.SerializedValue
Gets the size of the serialized state.
getSizes() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getSleepBetweenSqlRetries() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The number of milliseconds slept between two SQL retries.
getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
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.
getSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
Gets the number of the slot.
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.runtime.accumulators.AccumulatorRegistry
Creates a snapshot of this accumulator registry.
getSnapshotSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Gets the settings for asynchronous snapshots.
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
 
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.
getSourceComponent() - 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
 
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.
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.
getSqlExecutionPlan(String, Boolean) - Static method in class org.apache.flink.api.table.explain.PlanJsonParser
 
getSrcVertex() - Method in class org.apache.flink.graph.Triplet
 
getStackTrace() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
getStackTraces() - Method in class org.apache.flink.runtime.webmonitor.StackTraceSample
Returns the a map of stack traces by execution ID.
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
 
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() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getState() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getState(ClassLoader) - Method in class org.apache.flink.contrib.streaming.state.DbStateHandle
 
getState(String) - Method in class org.apache.flink.runtime.checkpoint.SavepointStore
 
getState() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
 
getState(String) - Method in interface org.apache.flink.runtime.checkpoint.StateStore
Returns the object identified by the given (logical) path.
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.messages.checkpoint.AcknowledgeCheckpoint
 
getState(ClassLoader) - Method in class org.apache.flink.runtime.state.AsynchronousStateHandle
 
getState(ClassLoader) - Method in class org.apache.flink.runtime.state.filesystem.FileSerializableStateHandle
 
getState(ClassLoader) - Method in class org.apache.flink.runtime.state.filesystem.FileStreamStateHandle
 
getState(ClassLoader) - Method in class org.apache.flink.runtime.state.LocalStateHandle
 
getState(ClassLoader) - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getState(ClassLoader) - Method in class org.apache.flink.runtime.state.memory.SerializedStateHandle
 
getState(ClassLoader) - Method in interface org.apache.flink.runtime.state.StateHandle
This retrieves and return the state represented by the handle.
getState() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getState(ClassLoader) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
 
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.operators.AbstractStreamOperator
 
getStateBackend() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Returns the state backend that defines how to store and checkpoint state.
getStateCache() - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
Return the Map of cached states.
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
 
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.runtime.checkpoint.CompletedCheckpoint
 
getStateSize() - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
 
getStateSize() - Method in class org.apache.flink.contrib.streaming.state.DbStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
Returns the state size in bytes.
getStateSize() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
getStateSize() - Method in class org.apache.flink.runtime.state.AsynchronousKvStateSnapshot
 
getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
Returns the file size in bytes.
getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.FileSerializableStateHandle
Returns the file size in bytes.
getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.FileStreamStateHandle
Returns the file size in bytes.
getStateSize() - Method in interface org.apache.flink.runtime.state.KvStateSnapshot
Returns the size of the state in bytes.
getStateSize() - Method in class org.apache.flink.runtime.state.LocalStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
 
getStateSize() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.memory.SerializedStateHandle
 
getStateSize() - Method in interface org.apache.flink.runtime.state.StateHandle
Returns the size of the state in bytes.
getStateSize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
 
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 class org.apache.flink.runtime.executiongraph.Execution
 
getStateTransitions() - Method in class org.apache.flink.cep.nfa.State
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.addons.hbase.TableInputFormat
 
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.examples.java.distcp.FileCopyTaskInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
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.messages.webmonitor.JobDetails
 
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 class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getStdoutLogging() - Method in class org.apache.flink.client.cli.ProgramOptions
 
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
 
getStreamEdges(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
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
 
getStreamOutputs() - 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
 
getStrigifiedStackTrace() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
getString(String, String) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a string.
getString(String, String) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Returns the value associated with the given key as a string.
getString(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
getString(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getString(String, String) - Method in class org.apache.flink.streaming.connectors.json.JSONParseFlatMap
Get the String value associated with a key form a JSON code.
getStringByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
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.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
 
getSubmissionTimeout() - Method in class org.apache.flink.runtime.messages.JobClientMessages$
 
getSubmissionTimeout() - Static method in class org.apache.flink.runtime.messages.JobClientMessages
 
getSubtask() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
 
getSubTaskDuration(int) - Method in class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
Returns the duration of a specific sub task.
getSubTaskStateSize(int) - Method in class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
Returns the state size of a specific sub task.
getSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
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
 
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.spargel.MessagingFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
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
 
getSymbols() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
getTableName() - Method in class org.apache.flink.addons.hbase.TableInputFormat
 
getTableName() - Method in class org.apache.flink.addons.hbase.TableInputSplit
Returns the table name.
getTag() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
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.
getTargetId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
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
 
getTargetVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getTask() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputSplit
 
getTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
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 class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the task's configuration object.
getTaskConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the task-wide configuration object, originally attache to the job vertex.
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
 
getTaskInfo() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the TaskInfo object for the subtask
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
 
getTaskManagerAkkaConfig(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getTaskManagerCount() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
getTaskManagerCount() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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
 
getTaskManagerNumSlots() - Method in class org.apache.flink.client.LocalExecutor
 
getTaskManagerNumSlots() - Method in class org.apache.flink.test.util.AbstractTestBase
 
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.
getTaskManagers() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getTaskManagersAsJava() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getTaskManagerSlots() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
getTaskManagerSlots() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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.deployment.TaskDeploymentDescriptor
Returns the task's name.
getTaskName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
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.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 class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
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().
getTaskToExecute() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
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
 
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
 
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
 
getters() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
getters() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PojoDescriptor
 
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
 
getTimeout(Configuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getTimeout(Configuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getTimestamp() - Method in class org.apache.flink.cep.nfa.ComputationState
 
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.DeclineCheckpoint
 
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 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.streamrecord.StreamRecord
Returns the timestamp associated with this stream value in milliseconds.
getTimeZone() - Method in class org.apache.flink.api.table.TableConfig
Returns the timezone for date/time/timestamp conversions.
getTitle() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
getTo() - Method in class org.apache.flink.util.NumberSequenceIterator
 
getTopic() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
getTopicPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
 
getTopics(List<LegacyFetcher.FetchPartition>) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher
Returns a unique list of topics from the topic partition list
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
 
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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
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
 
getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getTotalNumberOfBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getTotalNumberOfBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
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
 
getTotalNumPages() - Method in class org.apache.flink.runtime.memory.MemoryManager
Gets the total number of memory pages managed by this memory manager.
getTrackTerms() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function tells which terms are tracked.
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.
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.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
 
getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getTriggerTimestamp() - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
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
 
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
 
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.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() - 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.api.table.explain.Node
 
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(int) - Method in class org.apache.flink.optimizer.postpass.AbstractSchema
 
getType(int) - Method in class org.apache.flink.optimizer.postpass.SparseKeySchema
 
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.
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.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(int) - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
getTypeAt(String) - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
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.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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
getTypeException() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeInfo() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
Gets the type information described by this TypeHint.
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
 
getTypeNumber() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getTypes() - Method in class org.apache.flink.api.common.operators.Ordering
 
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
 
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<?>, boolean, boolean, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the unary operator's return type.
getUnaryOperatorReturnType(Function, Class<?>, 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
 
getUnderlyingType() - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
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.
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.
getUnit() - Method in class org.apache.flink.streaming.api.windowing.time.Time
Gets the time unit for this policy's time interval.
getUnpackedElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
 
getUnpackedElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
 
getUnpackedElements() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
 
getUnpackedElements() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
Returns all elements that are currently in the buffer.
getUpdateBcastVars() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Get the broadcast variables of the VertexUpdateFunction.
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.runtime.fs.hdfs.HadoopFileSystem
 
getUri() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getUrl() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The url of the first shard.
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
 
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.Execution
 
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.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.
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.
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.
getUserMap() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
Gets the map for user-defined accumulators.
getUserName() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The username used to connect to the database at the given urls.
getUserPassword() - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
The password used to connect to the database at the given url and username.
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
 
getUtc_offset() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getValue() - Method in class org.apache.flink.graph.Edge
 
getValue() - Method in class org.apache.flink.graph.Vertex
 
getValue() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getValue(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
 
getValue() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Returns the value wrapped in this stream value.
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 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.
getVariable() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
getVariable(BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
getVersion() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getVersion() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
getVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Returns the version of the code as String.
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.runtime.deployment.TaskDeploymentDescriptor
Returns the task's execution vertex ID.
getVertexID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getVertexIds(ExecutionEnvironment, long) - Static method in class org.apache.flink.graph.examples.utils.ExampleUtils
 
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.JobSnapshottingSettings
 
getVerticesToConfirm() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
 
getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getVerticesToTrigger() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
 
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
 
getWaitSec() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
This function tells how long TwitterSource waits for the tweets.
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.
getWebFrontendPort() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
 
getWebInterfaceURL() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Returns an URL (as a string) to the JobManager web interface, running next to the ApplicationMaster and JobManager in a YARN container
getWebInterfaceURL() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
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
 
getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getWindowBufferFactory() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
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.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
 
getWindowSlide() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
 
getWindowTime() - Method in class org.apache.flink.cep.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
 
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.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
 
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
 
getWriters() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
List of writers that are associated with this output collector
getYARNSessionCLIOptions(Options) - Method in class org.apache.flink.client.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).
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.
GlobalConfiguration - Class in org.apache.flink.configuration
Global configuration object for Flink.
GlobalJobParameters() - Constructor for class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
 
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
 
GlobalWindow - Class in org.apache.flink.streaming.api.windowing.windows
 
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 global window.
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.
Grade(long, 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$
 
gradeCount() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
gradeCount() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
GRADES_INPUT - Static variable in class org.apache.flink.streaming.examples.join.util.WindowJoinData
 
GradeSource() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoin.GradeSource
 
gradeStream() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
gradeStream() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
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
 
GradientDescentL1 - Class in org.apache.flink.ml.optimization
Implementation of a SGD solver with L1 regularization.
GradientDescentL1() - Constructor for class org.apache.flink.ml.optimization.GradientDescentL1
 
GradientDescentL1$ - Class in org.apache.flink.ml.optimization
 
GradientDescentL1$() - Constructor for class org.apache.flink.ml.optimization.GradientDescentL1$
 
GradientDescentL2 - Class in org.apache.flink.ml.optimization
Implementation of a SGD solver with L2 regularization.
GradientDescentL2() - Constructor for class org.apache.flink.ml.optimization.GradientDescentL2
 
GradientDescentL2$ - Class in org.apache.flink.ml.optimization
 
GradientDescentL2$() - Constructor for class org.apache.flink.ml.optimization.GradientDescentL2$
 
grantLeadership(UUID) - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
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$() - 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<K,VV,EV> - Class in org.apache.flink.graph.scala
Represents a graph consisting of edges and 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
 
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
 
GraphMetrics - Class in org.apache.flink.graph.examples
This example illustrates how to use Gelly metrics methods and get simple statistics from the input graph.
GraphMetrics() - Constructor for class org.apache.flink.graph.examples.GraphMetrics
 
GraphMetrics - Class in org.apache.flink.graph.scala.examples
This example illustrates how to use Gelly metrics methods and get simple statistics from the input graph.
GraphMetrics() - Constructor for class org.apache.flink.graph.scala.examples.GraphMetrics
 
GraphMetrics$ - Class in org.apache.flink.graph.scala.examples
This example illustrates how to use Gelly metrics methods and get simple statistics from the input graph.
GraphMetrics$() - Constructor for class org.apache.flink.graph.scala.examples.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
 
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
 
GreaterThan - Class in org.apache.flink.api.table.expressions
 
GreaterThan(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.GreaterThan
 
greaterThan() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
greaterThan() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
GreaterThan$ - Class in org.apache.flink.api.table.expressions
 
GreaterThan$() - Constructor for class org.apache.flink.api.table.expressions.GreaterThan$
 
GreaterThanOrEqual - Class in org.apache.flink.api.table.expressions
 
GreaterThanOrEqual(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.GreaterThanOrEqual
 
greaterThanOrEqual() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
greaterThanOrEqual() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
GreaterThanOrEqual$ - Class in org.apache.flink.api.table.expressions
 
GreaterThanOrEqual$() - Constructor for class org.apache.flink.api.table.expressions.GreaterThanOrEqual$
 
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>) - 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 - Class in org.apache.flink.api.table.plan
Grouping operation.
GroupBy(PlanNode, Seq<Expression>) - Constructor for class org.apache.flink.api.table.plan.GroupBy
 
groupBy(Seq<Expression>) - Method in class org.apache.flink.api.table.Table
Groups the elements on some grouping keys.
groupBy(String) - Method in class org.apache.flink.api.table.Table
Groups the elements on some grouping keys.
GroupBy$ - Class in org.apache.flink.api.table.plan
 
GroupBy$() - Constructor for class org.apache.flink.api.table.plan.GroupBy$
 
GroupByAnalyzer - Class in org.apache.flink.api.table.expressions.analysis
Analyzer for grouping expressions.
GroupByAnalyzer(Seq<Tuple2<String, TypeInformation<?>>>) - Constructor for class org.apache.flink.api.table.expressions.analysis.GroupByAnalyzer
 
GroupByAnalyzer.CheckGroupExpression - Class in org.apache.flink.api.table.expressions.analysis
 
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
 
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
 
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,EV> - Class in org.apache.flink.graph.library
This is an implementation of the Connected Components algorithm, using a gather-sum-apply iteration.
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.library
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.library.GSAPageRank
Creates an instance of the GSA PageRank algorithm.
GSAPageRank(double, long, int) - Constructor for class org.apache.flink.graph.library.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> - 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> - Class in org.apache.flink.graph.library
 
GSATriangleCount<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library
Triangle Count Algorithm.
GSATriangleCount() - Constructor for class org.apache.flink.graph.library.GSATriangleCount
 
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

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
HadoopDataInputStream - Class in org.apache.flink.runtime.fs.hdfs
Concrete implementation of the FSDataInputStream for the Hadoop Distributed File System.
HadoopDataInputStream(FSDataInputStream) - Constructor for class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
Creates a new data input stream from the given HDFS 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
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
 
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.
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
 
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.
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
 
handIn(String, V) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
hand in the object to share
handleDiscardedMessage(Option<UUID>, JobManagerMessages.LeaderSessionMessage) - Method in interface org.apache.flink.runtime.LeaderSessionMessageFilter
 
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 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.net.ConnectionUtils.LeaderConnectingAddressListener
 
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
 
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(ActorRef, String) - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
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.checkpoint.CheckpointCoordinatorDeActivator
 
handleMessage(Object) - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinatorDeActivator
 
handleMessage(Object) - Method in class org.apache.flink.runtime.client.JobClientActor
 
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() - Method in class org.apache.flink.yarn.YarnJobManager
 
handleMessage() - Method in class org.apache.flink.yarn.YarnTaskManager
 
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(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractExecutionGraphRequestHandler
 
handleRequest(ExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractExecutionGraphRequestHandler
 
handleRequest(ExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractJobVertexRequestHandler
 
handleRequest(ExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractJobVertexRequestHandler
 
handleRequest(ExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskAttemptRequestHandler
 
handleRequest(Execution, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskAttemptRequestHandler
 
handleRequest(ExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskRequestHandler
 
handleRequest(ExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskRequestHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.ClusterOverviewHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.CurrentJobIdsHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.CurrentJobsOverviewHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.DashboardConfigHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarAccessDeniedHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHandler
 
handleRequest(ExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobAccumulatorsHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobCancellationHandler
 
handleRequest(ExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobCheckpointsHandler
 
handleRequest(ExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobConfigHandler
 
handleRequest(ExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobDetailsHandler
 
handleRequest(ExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobExceptionsHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobManagerConfigHandler
 
handleRequest(ExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobPlanHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobStoppingHandler
 
handleRequest(ExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexAccumulatorsHandler
 
handleRequest(ExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexBackPressureHandler
 
handleRequest(ExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexCheckpointsHandler
 
handleRequest(ExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexDetailsHandler
 
handleRequest(ExecutionJobVertex, 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(ExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskCurrentAttemptDetailsHandler
 
handleRequest(Execution, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptAccumulatorsHandler
 
handleRequest(Execution, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptDetailsHandler
 
handleRequest(ExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksAllAccumulatorsHandler
 
handleRequest(ExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksTimesHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.TaskManagersHandler
 
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
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor.FailingHandler
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor.IgnoringHandler
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor.LoggingHandler
 
handleViolation(long, long) - Method in interface org.apache.flink.streaming.api.functions.AscendingTimestampExtractor.MonotonyViolationHandler
Called when the property of monotonously ascending timestamps is violated, i.e., when elementTimestamp < lastTimestamp.
handleYarnMessage() - Method in class org.apache.flink.yarn.YarnJobManager
 
handleYarnMessages() - Method in class org.apache.flink.yarn.YarnTaskManager
 
Hardware - Class in org.apache.flink.runtime.instance
Convenience class to extract hardware specifics of the computer executing this class
HardwareDescription - Class in org.apache.flink.runtime.instance
A hardware description describes the resources available to a task manager.
HardwareDescription() - Constructor for class org.apache.flink.runtime.instance.HardwareDescription
Public default constructor used for serialization process.
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.
hasAlt() - Method in class org.apache.flink.api.java.utils.Option
 
hasBackPressure() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
hasBeenStopped() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Boolean indicating whether the cluster has been stopped already
hasBeenStopped() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
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
 
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
 
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
 
hasFailed() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Boolean indicating whether the Flink YARN cluster is in an erronous state.
hasFailed() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
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.
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.
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(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.PojoComparator
 
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(T) - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
hash(Row) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
hash(int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
This function hashes an integer value.
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.
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.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.StateDescriptor
 
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.TypeHint
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
 
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.TypeSerializerSingleton
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
 
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.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.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.PojoSerializer
 
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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
hashCode() - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
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.SharedBuffer
 
hashCode() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
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.configuration.Configuration
 
hashCode() - Method in class org.apache.flink.core.fs.FileInputSplit
 
hashCode() - Method in class org.apache.flink.core.fs.FileSystem.FSKey
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.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() - Method in class org.apache.flink.optimizer.postpass.SparseKeySchema
 
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.StateForTask
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
 
hashCode() - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
 
hashCode() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
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 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.messages.checkpoint.AbstractCheckpointMessage
 
hashCode() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
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.operators.util.TaskConfig.DelegatingConfiguration
 
hashCode() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
hashCode() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
 
hashCode() - Method in class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
 
hashCode() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
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.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.GlobalWindow.Serializer
 
hashCode() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
hashCode() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
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.MultiplexingStreamRecordSerializer
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
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.Pair
 
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.SerializedValue
 
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
 
HashPartition<BT,PT> - Class in org.apache.flink.runtime.operators.hash
 
HashPartition.BuildSideBuffer - Class in org.apache.flink.runtime.operators.hash
 
HashPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner selects the target channel based on the hash value of a key from a KeySelector.
HashPartitioner(KeySelector<T, ?>) - Constructor for class org.apache.flink.streaming.runtime.partitioner.HashPartitioner
 
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
 
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
 
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
 
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.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.jobgraph.tasks.InputSplitIterator
 
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.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.runtime.util.UnionIterator
 
hasNext() - Method in class org.apache.flink.util.NumberSequenceIterator
 
hasNoConnectedInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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.
hasPublicNullaryConstructor(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the given class has a public nullary constructor.
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
 
hasRemaining(int) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
 
hasResourcesAvailable() - Method in class org.apache.flink.runtime.instance.Instance
 
hasStreamingMode(Map<String, String>) - Method in class org.apache.flink.yarn.ApplicationMasterBase$
 
hasStreamingMode(Map<String, String>) - Static method in class org.apache.flink.yarn.ApplicationMasterBase
 
hasStubWrapper() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
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.
haveAllOutputConnectionInterestingProperties() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Checks, if all outgoing connections have their interesting properties set from their target nodes.
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
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
 
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.
HeapSort - Class in org.apache.flink.runtime.operators.sort
 
HeapSort() - Constructor for class org.apache.flink.runtime.operators.sort.HeapSort
 
Heartbeat(InstanceID, byte[], 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() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
HEARTBEAT_INTERVAL() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
HeartbeatWithYarn$() - Constructor for class org.apache.flink.yarn.YarnMessages.HeartbeatWithYarn$
 
HeavyHitter - Interface in org.apache.flink.contrib.operatorstatistics.heavyhitters
Interface for classes that track heavy hitters.
heavyHitterAlgorithm - Variable in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
HeavyHitterMergeException - Exception in org.apache.flink.contrib.operatorstatistics.heavyhitters
Exception that is thrown when incompatible heavy hitter sketches attempt to be merged.
HeavyHitterMergeException(String) - Constructor for exception org.apache.flink.contrib.operatorstatistics.heavyhitters.HeavyHitterMergeException
 
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.RollingSink
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
 
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
 
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
 
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.runtime.minicluster.FlinkMiniCluster
 
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.
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() - Constructor for class org.apache.flink.runtime.webmonitor.HttpRequestHandler
 
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.

I

i() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.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.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.examples.scala.TPCHQuery3Table.Customer
 
id() - Method in class org.apache.flink.examples.scala.TPCHQuery3Table.Lineitem
 
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 - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
id - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
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
 
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
 
IdentityGroupReduce<IN> - Class in org.apache.flink.python.api.functions.util
 
IdentityGroupReduce() - Constructor for class org.apache.flink.python.api.functions.util.IdentityGroupReduce
 
IdPartitioner - Class in org.apache.flink.api.java.functions
 
IdPartitioner() - Constructor for class org.apache.flink.api.java.functions.IdPartitioner
 
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.
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.
IgnoringHandler() - Constructor for class org.apache.flink.streaming.api.functions.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.
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
 
ImplicitExpressionConversions - Interface in org.apache.flink.api.scala.table
Implicit conversions from Scala Literals to Expression Literal and from Expression to ImplicitExpressionOperations.
ImplicitExpressionConversions.LiteralBooleanExpression - Class in org.apache.flink.api.scala.table
 
ImplicitExpressionConversions.LiteralDoubleExpression - Class in org.apache.flink.api.scala.table
 
ImplicitExpressionConversions.LiteralFloatExpression - Class in org.apache.flink.api.scala.table
 
ImplicitExpressionConversions.LiteralIntExpression - Class in org.apache.flink.api.scala.table
 
ImplicitExpressionConversions.LiteralLongExpression - Class in org.apache.flink.api.scala.table
 
ImplicitExpressionConversions.LiteralStringExpression - Class in org.apache.flink.api.scala.table
 
ImplicitExpressionConversions.SymbolExpression - Class in org.apache.flink.api.scala.table
 
ImplicitExpressionConversions.WithOperations - Class in org.apache.flink.api.scala.table
 
ImplicitExpressionOperations - Interface in org.apache.flink.api.scala.table
These are all the operations that can be used to construct an Expression AST for expression operations.
in - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
InBlockInformation(int[], ALS.BlockRating[]) - Constructor for class org.apache.flink.ml.recommendation.ALS.InBlockInformation
 
InBlockInformation$() - Constructor for class org.apache.flink.ml.recommendation.ALS.InBlockInformation$
 
includeConfiguration(Configuration) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Merges the given Configuration object into the global configuration.
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.
includeManifest() - Method in class org.apache.flink.runtime.akka.serialization.IOReadableWritableSerializer
 
includeManifest() - Method in class org.apache.flink.runtime.akka.serialization.WritableSerializer
 
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.
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.
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.api.table.codegen
 
Indenter() - Constructor for class org.apache.flink.api.table.codegen.Indenter
 
Indenter$ - Class in org.apache.flink.api.table.codegen
 
Indenter$() - Constructor for class org.apache.flink.api.table.codegen.Indenter$
 
IndentStringContext - Class in org.apache.flink.api.table.codegen
 
IndentStringContext(StringContext) - Constructor for class org.apache.flink.api.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.
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
Function that creates an IndexRequest from an element in a Stream.
indices() - Method in class org.apache.flink.ml.math.SparseVector
 
INF_TIMEOUT() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
INF_TIMEOUT() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
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 InflaterInputStream> - 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.
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.
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
 
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.
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_PRIORITY_QUEUE_CAPACITY - Static variable in class org.apache.flink.cep.operator.AbstractCEPPatternOperator
 
INITIAL_REGISTRATION_TIMEOUT() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
INITIAL_REGISTRATION_TIMEOUT() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
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.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(FlinkLocalCluster.LocalClusterFactory) - Static method in class org.apache.flink.storm.api.FlinkLocalCluster
Sets a different factory for FlinkLocalClusters to be used for execution.
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
 
initializeClient(DefaultStreamingEndpoint, Authentication) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
initializeConnection() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
Initializes the connection to RMQ.
initializeConnection() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
 
initializeConnection() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
Initialize Hosebird Client to be able to consume Twitter's Streaming API
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
 
initializeFactory(MemorySegmentFactory.Factory) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Initializes this factory with the given concrete factory.
initializeFields(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
initializeForJob(Environment, String, TypeSerializer<?>) - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
 
initializeForJob(Environment, String, TypeSerializer<?>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
initializeForJob(Environment, String, TypeSerializer<?>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
This method is called by the task upon deployment to initialize the state backend for data for a specific job.
initializeForJob(Environment, String, TypeSerializer<?>) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
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.
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
 
initializeSerializerUnlessSet(ExecutionConfig) - Method in class org.apache.flink.api.common.state.StateDescriptor
Initializes the serializer, unless it has been initialized before.
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)!
initMaxDepth() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
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.
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.
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, AccumulatorRegistry.Reporter, Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
Creates a writer for each output.
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
 
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
 
injectKeyValueStateSnapshots(HashMap<String, KvStateSnapshot>, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Injects K/V state snapshots for lazy restore.
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
 
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() - Method in class org.apache.flink.api.table.plan.Aggregate
 
input() - Method in class org.apache.flink.api.table.plan.As
 
input() - Method in class org.apache.flink.api.table.plan.Filter
 
input() - Method in class org.apache.flink.api.table.plan.GroupBy
 
input() - Method in class org.apache.flink.api.table.plan.Root
 
input() - Method in class org.apache.flink.api.table.plan.Select
 
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
 
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
 
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
 
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, Tuple2<Integer, Integer>) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
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
 
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
 
InputFormat<OT,T extends InputSplit> - Interface in org.apache.flink.api.common.io
The base interface for data sources that produces records.
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
 
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, int, InputChannelDeploymentDescriptor[]) - Constructor for class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
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.
inputs - Variable in class org.apache.flink.runtime.operators.BatchTask
The inputs to the operator.
inputSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
This is used to copy the incoming element because it can be put into several window buffers.
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.
InputSplitIterator<T extends InputSplit> - Class in org.apache.flink.runtime.jobgraph.tasks
The input split iterator allows a task to iterate over all input splits it is supposed to consume.
InputSplitIterator(InputSplitProvider) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.InputSplitIterator
Constructs a new input split iterator.
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.
InputSplitSource<T extends InputSplit> - Interface in org.apache.flink.core.io
InputSplitSources create InputSplits that define portions of data to be produced by InputFormats.
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
 
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.
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
 
insert(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
insert(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
InsertAutoCasts - Class in org.apache.flink.api.table.expressions.analysis
Rule that adds casts in arithmetic operations.
InsertAutoCasts() - Constructor for class org.apache.flink.api.table.expressions.analysis.InsertAutoCasts
 
insertBatch(String, DbBackendConfig, Connection, PreparedStatement, long, List<Tuple2<byte[], byte[]>>) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Insert a list of Key-Value pairs into the database.
insertBatch(String, DbBackendConfig, Connection, PreparedStatement, long, List<Tuple2<byte[], byte[]>>) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
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.
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.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.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.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.optimizer.util.NoOpUnaryUdfOp
 
instance() - Static method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
 
Instance - Class in org.apache.flink.runtime.instance
An instance represents a TaskManager registered at a JobManager and ready to receive work.
Instance(ActorGateway, InstanceConnectionInfo, 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.util.ExecutorThreadFactory
 
INSTANCE - Static variable in class org.apache.flink.streaming.runtime.io.BlockingQueueBroker
Singleton instance
InstanceConnectionInfo - Class in org.apache.flink.runtime.instance
This class encapsulates the connection information of a TaskManager.
InstanceConnectionInfo(InetAddress, int) - Constructor for class org.apache.flink.runtime.instance.InstanceConnectionInfo
Constructs a new instance connection info object.
InstanceConnectionInfo() - Constructor for class org.apache.flink.runtime.instance.InstanceConnectionInfo
Constructs an empty object.
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.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
 
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 also load user-code using a user-code ClassLoader.
int2Literal(int) - Method in interface org.apache.flink.api.scala.table.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_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
 
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
 
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
 
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(JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
IntermediateDataSet(IntermediateDataSetID, JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
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.
IntermediateResult - Class in org.apache.flink.runtime.executiongraph
 
IntermediateResult(IntermediateDataSetID, ExecutionJobVertex, int, ResultPartitionType, boolean) - 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
 
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.
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.
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
 
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
 
InternalWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal interface for functions that are evaluated over keyed (grouped) windows.
InternalWindowFunction() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
 
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.
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
 
IntSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.IntSum
 
IntSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
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.
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.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.PojoComparator
 
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.table.typeinfo.NullAwareComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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(T) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
 
invoke(IN) - Method in class org.apache.flink.streaming.connectors.flume.FlumeSink
Receives tuples from the Apache Flink DataStream and forwards them to Apache Flume.
invoke(T) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
 
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(Tuple5<Long, Integer, String, String, String>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterStreaming.TwitterSink
 
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.
InvScaling(double) - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.InvScaling
 
InvScaling$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.InvScaling$
 
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
 
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.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.
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.runtime.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.
isAbsolute() - Method in class org.apache.flink.core.fs.Path
Checks if the directory of this path is absolute.
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.
isArchived() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isAssigned() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Checks whether the location of this constraint has been assigned.
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.
isAssociated() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
isBasicValueType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isBlocking() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
isBotEdit() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
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 interface org.apache.flink.runtime.execution.ExecutionObserver
Returns whether the task has been canceled.
isCanceled() - Method in class org.apache.flink.runtime.instance.Slot
Checks of the slot has been cancelled.
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.
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
 
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
 
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.TypeExtractor
 
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
 
isClosureCleanerEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns whether the ClosureCleaner is enabled.
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
 
isCompactor() - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
Used for testing purposes
isCompatibleWith(DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber
Checks whether this dewey number is compatible to the other dewey number.
isComputablyPartitioned() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
Checks, if this property represents a partitioning that is computable.
isConnected() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Checks whether the TaskManager is currently connected to its JobManager.
isConnected() - Method in class org.apache.flink.yarn.ApplicationClient
True if the ApplicationClient is connected to the YarnJobManager
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
 
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.runtime.yarn.AbstractFlinkYarnClient
 
isDetached() - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Flink's YARN cluster abstraction has two modes for connecting to the YARN AM.
isDetached() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
isDetached() - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
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.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.
isDistributedFS() - Method in class org.apache.flink.core.fs.FileSystem
Returns true if this is a distributed file system, false otherwise.
isDistributedFS() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
isDistributedFS() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
isDistributedFS() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
isEmpty() - Method in class org.apache.flink.api.common.operators.Keys
 
isEmpty() - Method in class org.apache.flink.cep.nfa.SharedBuffer
 
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.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.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.streaming.runtime.tasks.StreamTaskState
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.streaming.runtime.tasks.StreamTaskStateList
 
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 interface org.apache.flink.streaming.util.serialization.DeserializationSchema
Method to decide whether the element signals the end of the stream.
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
 
isEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
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
 
isExtremal(Comparable<R>, R) - Method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
 
isFavorited() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
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
 
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.
isForceKryoEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
 
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.
isFullBuffer() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
 
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
 
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
 
isGrouped() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isHighAvailabilityModeActivated(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.RecoveryMode
Returns true if the defined recovery mode supports high availability.
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.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.LongSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
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.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.TypeSerializer
Gets whether the type is an immutable type.
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.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.api.table.typeinfo.RowSerializer
 
isImmutableType() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
isImmutableType() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
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.MultiplexingStreamRecordSerializer
 
isImmutableType() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
isInFinalState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
isInitialized() - Method in class org.apache.flink.contrib.streaming.state.DbStateBackend
Check whether the backend has been initialized.
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).
isInitialized() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Checks whether this state backend is initialized.
isInMemory() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
Checks whether this partition is in memory or spilled.
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
 
isInputCopyingDisabled() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
isInputCopyingDisabled() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
An operator can return true here to disable copying of its input elements.
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
 
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
 
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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
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.
isLocal() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isMac() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Windows.
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
 
isMerged - Variable in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
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
 
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.BooleanComparator
 
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.CharComparator
 
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.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.IntComparator
 
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.ShortComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
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.PojoComparator
 
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.table.typeinfo.NullAwareComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
isNotifications() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isNotNull() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
IsNotNull - Class in org.apache.flink.api.table.expressions
 
IsNotNull(Expression) - Constructor for class org.apache.flink.api.table.expressions.IsNotNull
 
isNotNull() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
isNotNull() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
IsNotNull$ - Class in org.apache.flink.api.table.expressions
 
IsNotNull$() - Constructor for class org.apache.flink.api.table.expressions.IsNotNull$
 
isNull() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isNull() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
IsNull - Class in org.apache.flink.api.table.expressions
 
IsNull(Expression) - Constructor for class org.apache.flink.api.table.expressions.IsNull
 
isNull() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
isNull() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
isNull(int) - Method in class org.apache.flink.types.Record
 
IsNull$ - Class in org.apache.flink.api.table.expressions
 
IsNull$() - Constructor for class org.apache.flink.api.table.expressions.IsNull$
 
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.
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() - 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.
isPersistent() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
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.runtime.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.
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).
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
 
isQueuedSchedulingAllowed() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isReadyForDeployment() - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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
 
isRegistered(ActorRef) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
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.consumer.UnknownInputChannel
Returns false.
isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
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.
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.
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.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
 
isScheduleLocalOnly() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
isSecurityEnabled() - Static method in class org.apache.flink.runtime.security.SecurityUtils
 
isSerializerInitialized() - Method in class org.apache.flink.api.common.state.StateDescriptor
Checks whether the serializer has been initialized.
isSerializingTimestamps() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
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.io.network.NetworkEnvironment
 
isShutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
Checks whether the MemoryManager has been shut down.
isSkipInvalidLines() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
isSkippingFirstLineAsHeader() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
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
 
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
 
isSpecial() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
isStart() - Method in class org.apache.flink.cep.nfa.State
 
isStartState() - Method in class org.apache.flink.cep.nfa.ComputationState
 
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.
isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isStoppable() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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
 
isTerminal() - Method in enum org.apache.flink.runtime.execution.ExecutionState
 
isTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
 
isThis() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
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.
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.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.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.api.table.typeinfo.RenamingProxyTypeInfo
 
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
 
isUsingInteractiveMode() - Method in class org.apache.flink.client.program.PackagedProgram
 
isUsingProgramEntryPoint() - Method in class org.apache.flink.client.program.PackagedProgram
 
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.
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 class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a watermark.
isWindows() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Windows.
isWorksetIteration - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
isWorksetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
isZooKeeperRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Returns whether RecoveryMode.ZOOKEEPER is configured.
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>>) - 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>) - 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<?>>>) - 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
 
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$() - 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.
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 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.graph.spargel.MessageIterator
 
iterator() - Method in class org.apache.flink.optimizer.postpass.SparseKeySchema
 
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.util.EmptyIterator
 
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.runtime.util.UnionIterator
 
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.types.ListValue
 
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.api.table.codegen.IndentStringContext
 
JACCARD_EDGES - Static variable in class org.apache.flink.graph.examples.data.JaccardSimilarityMeasureData
 
JaccardSimilarityMeasure - Class in org.apache.flink.graph.examples
This example shows how to use neighborhood methods join with vertices triplets Given a directed, unweighted graph, return a weighted graph where the edge values are equal to the Jaccard similarity coefficient - the number of common neighbors divided by the the size of the union of neighbor sets - for the src and target vertices.
JaccardSimilarityMeasure() - Constructor for class org.apache.flink.graph.examples.JaccardSimilarityMeasure
 
JaccardSimilarityMeasureData - Class in org.apache.flink.graph.examples.data
Provides the default data sets used for the Jaccard Similarity Measure example program.
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.
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) - 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
 
JavaBatchTranslator - Class in org.apache.flink.api.java.table
PlanTranslator for creating Tables from Java DataSets and translating them back to Java DataSets.
JavaBatchTranslator() - Constructor for class org.apache.flink.api.java.table.JavaBatchTranslator
 
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
 
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.
JavaStreamingTranslator - Class in org.apache.flink.api.java.table
PlanTranslator for creating Tables from Java DataStreams and translating them back to Java DataStreams.
JavaStreamingTranslator() - Constructor for class org.apache.flink.api.java.table.JavaStreamingTranslator
 
JavaTableExample - Class in org.apache.flink.examples.java
Very simple example that shows how the Java Table API can be used.
JavaTableExample() - Constructor for class org.apache.flink.examples.java.JavaTableExample
 
JavaTableExample.WC - Class in org.apache.flink.examples.java
 
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<OUT extends Tuple> - Class in org.apache.flink.api.java.io.jdbc
InputFormat to read data from a database and generate tuples.
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<OUT extends Tuple> - Class in org.apache.flink.api.java.io.jdbc
OutputFormat to write tuples into a 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
 
jenkinsHash(int) - Static method in class org.apache.flink.runtime.util.MathUtils
This function hashes an integer value.
job() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJob
 
JOB_MANAGER_IPC_ADDRESS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the network address to connect to for communication with the job manager.
JOB_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 job manager.
JOB_MANAGER_NAME() - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Name of the JobManager actor
JOB_MANAGER_NAME() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Name of the JobManager actor
JOB_MANAGER_WEB_ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the number of archived jobs for the jobmanager
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 if not accessed.
JOB_MANAGER_WEB_BACK_PRESSURE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
Delay between stack trace samples to determine back pressure.
JOB_MANAGER_WEB_BACK_PRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
Number of stack trace samples to take to determine back pressure.
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).
JOB_MANAGER_WEB_CHECKPOINTS_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Flag to disable checkpoint stats.
JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Config parameter defining the number of checkpoints to remember for recent history.
JOB_MANAGER_WEB_LOG_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The log file location (may be in /log for standalone but under log directory when using YARN)
JOB_MANAGER_WEB_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The port for the runtime monitor web-frontend server.
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_SUBMIT_ENABLED_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Config parameter indicating whether jobs can be uploaded and run from the web-frontend.
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
 
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
 
JobCheckpointsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns checkpoint stats for a job.
JobCheckpointsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobCheckpointsHandler
 
JobCheckpointStats - Interface in org.apache.flink.runtime.checkpoint.stats
Snapshot of checkpoint statistics for a job.
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
 
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.ConnectionTimeout$ - Class in org.apache.flink.runtime.messages
Messaeg which is triggered when the connection timeout has been reached.
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.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 JobClient (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
 
JobClientMessages.SubmitJobDetached - Class in org.apache.flink.runtime.messages
This message is sent to the JobClient (via ask) to submit a job and return as soon as the result of the submit operation is known.
JobClientMessages.SubmitJobDetached$ - 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
 
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) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobDetailsHandler
 
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
 
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.
JobFound(JobID, ExecutionGraph) - 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() - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with no name and a random job ID.
JobGraph(String) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name, a random job ID.
JobGraph(JobID, String) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name and a random job ID if null supplied as an id.
JobGraph(JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with no name and a random job ID if null supplied as an id.
JobGraph(String, JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name and a random job ID.
JobGraph(JobID, String, JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name and a random job ID if null supplied as an id.
jobGraph() - Method in class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobAndWait
 
jobGraph() - Method in class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobDetached
 
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 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.JobManagerMessages.CancelJob
 
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.RemoveCachedJob
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RemoveJob
 
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.RequestPartitionState
 
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() - Method in class org.apache.flink.yarn.YarnMessages.LocalStopAMAfterJob
 
jobId() - Method in class org.apache.flink.yarn.YarnMessages.StopAMAfterJob
 
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$
 
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, ExecutorService, InstanceManager, Scheduler, BlobLibraryCacheManager, ActorRef, RestartStrategy, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, SavepointStore, FiniteDuration) - 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.messages.TaskManagerMessages.JobManagerLeaderAddress
 
jobManagerAkkaURL() - Method in class org.apache.flink.yarn.YarnMessages.JobManagerLeaderAddress
 
jobManagerAkkaURL() - Method in class org.apache.flink.yarn.YarnMessages.TriggerApplicationClientRegistration
 
JobManagerCliOptions - Class in org.apache.flink.runtime.jobmanager
The command line parameters passed to the TaskManager.
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
 
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$
 
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.CancellationFailure - Class in org.apache.flink.runtime.messages
Denotes a failed job cancellation
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
JobManagerMessages.CancellationSuccess$ - 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.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.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.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.RequestPartitionState - Class in org.apache.flink.runtime.messages
Requests the current state of the partition.
JobManagerMessages.RequestPartitionState$ - 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
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
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
 
JobManagerMode - Enum in org.apache.flink.runtime.jobmanager
The startup mode for the JobManager.
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
 
JobManagerStatusAlive$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobManagerStatusAlive$
 
JobManagerStopped$() - Constructor for class org.apache.flink.yarn.YarnMessages.JobManagerStopped$
 
jobManagerURL() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration
 
jobName - Variable in class org.apache.flink.api.common.Plan
The name of the job.
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
 
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$
 
jobs() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs
 
JobSnapshottingSettings - 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.
JobSnapshottingSettings(List<JobVertexID>, List<JobVertexID>, List<JobVertexID>, long, long, long, int) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
 
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$
 
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
 
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.
JobVertexAccumulatorsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobVertexAccumulatorsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexAccumulatorsHandler
 
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
 
JobVertexCheckpointsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns checkpoint stats for a single job vertex.
JobVertexCheckpointsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexCheckpointsHandler
 
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) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexDetailsHandler
 
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
 
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) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexTaskManagersHandler
 
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>) - 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 - Class in org.apache.flink.api.table.plan
Operation that joins two Tables.
Join(PlanNode, PlanNode) - Constructor for class org.apache.flink.api.table.plan.Join
 
join(L, R, Collector<O>) - Method in class org.apache.flink.api.table.runtime.ExpressionJoinFunction
 
join(Table) - Method in class org.apache.flink.api.table.Table
Joins two Tables.
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(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(Tuple3<Long, String, Integer>, Tuple3<Long, String, Integer>) - Method in class org.apache.flink.streaming.examples.join.WindowJoin.MyJoinFunction
 
Join$ - Class in org.apache.flink.api.table.plan
 
Join$() - Constructor for class org.apache.flink.api.table.plan.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
 
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
 
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
 
JoinVertexWithEdgesMatch() - Constructor for class org.apache.flink.examples.java.graph.PageRank.JoinVertexWithEdgesMatch
 
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>) - 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>) - 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.
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
 
JSONGenerator(StreamGraph) - Constructor for class org.apache.flink.streaming.api.graph.JSONGenerator
 
JsonMapper - Class in org.apache.flink.optimizer.plantranslate
 
JsonMapper() - Constructor for class org.apache.flink.optimizer.plantranslate.JsonMapper
 
JSONParseFlatMap<IN,OUT> - Class in org.apache.flink.streaming.connectors.json
Abstract class derived from RichFlatMapFunction to handle JSON files.
JSONParseFlatMap() - Constructor for class org.apache.flink.streaming.connectors.json.JSONParseFlatMap
 
JSONParser - Class in org.apache.flink.streaming.connectors.json
A JSONParser contains a JSONObject and provides opportunity to access embedded fields in JSON code.
JSONParser(String) - Constructor for class org.apache.flink.streaming.connectors.json.JSONParser
Construct a JSONParser from a string.
JsonPlanGenerator - Class in org.apache.flink.runtime.jobgraph.jsonplan
 
JsonPlanGenerator() - Constructor for class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
 

K

kafkaMetric - Variable in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
KafkaPartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
It contains a open() method which is called on each parallel instance.
KafkaPartitioner() - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaPartitioner
 
KafkaTopicPartition - Class in org.apache.flink.streaming.connectors.kafka.internals
A serializable representation of a kafka topic and a partition.
KafkaTopicPartition(String, int) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
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
 
KafkaUtils - Class in org.apache.flink.streaming.connectors.kafka.util
 
KafkaUtils() - Constructor for class org.apache.flink.streaming.connectors.kafka.util.KafkaUtils
 
keepAlive(Connection) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Execute a simple operation to refresh the current database connection in case no data is written for a longer time period.
keepAlive(Connection) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
keepBuildSidePartitions - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
If true, build side partitions are kept for multiple probe steps.
key - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
key() - Method in class org.apache.flink.api.table.parser.ExpressionParser.Keyword
 
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<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 versions as well.
KEY_DISABLE_METRICS - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
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_POLL_TIMEOUT - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
Configuration key to change the polling timeout
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 DataStreamusing 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
 
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.
KeyedCEPPatternOperator<IN,KEY> - Class in org.apache.flink.cep.operator
CEP pattern operator implementation for a keyed input stream.
KeyedCEPPatternOperator(TypeSerializer<IN>, boolean, KeySelector<IN, KEY>, TypeSerializer<KEY>, NFACompiler.NFAFactory<IN>) - Constructor for class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
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
 
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
 
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
 
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
keyPositions() - Method in class org.apache.flink.api.table.typeinfo.RowComparator
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 - Variable in class org.apache.flink.api.java.operators.Grouping
 
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.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 arbitrary objects for operations such as reduce, reduceGroup, join, coGoup, etc.
keySelector - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
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
 
keySerializer - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
Key serializer
keySerializer - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Serializer for the keys
keySerializer - Variable in class org.apache.flink.runtime.state.AbstractHeapState
The serializer for the keys
keySerializer - Variable in class org.apache.flink.runtime.state.AbstractStateBackend
 
keySerializer - Variable in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
Key Serializer
keySerializer - Variable in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
Key Serializer
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.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
keySet() - Method in class org.apache.flink.storm.util.StormConfig
 
keySet() - Method in class org.apache.flink.types.MapValue
 
keyType(Class<K>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input without vertex values or edge values.
Keyword(String) - Constructor for class org.apache.flink.api.table.parser.ExpressionParser.Keyword
 
Keyword$() - Constructor for class org.apache.flink.api.table.parser.ExpressionParser.Keyword$
 
keyword2Parser(ExpressionParser.Keyword) - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
keyword2Parser(ExpressionParser.Keyword) - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
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
 
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.
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
 
KvState<K,N,S extends State,SD extends StateDescriptor<S,?>,Backend extends AbstractStateBackend> - Interface in org.apache.flink.runtime.state
Key/Value state implementation for user-defined state.
KvStateSnapshot<K,N,S extends State,SD extends StateDescriptor<S,?>,Backend extends AbstractStateBackend> - Interface in org.apache.flink.runtime.state
This class represents a snapshot of the KvState, taken for a checkpoint.

L

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
 
Lambda$() - Constructor for class org.apache.flink.ml.recommendation.ALS.Lambda$
 
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
 
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
latestClusterStatus() - Method in class org.apache.flink.yarn.ApplicationClient
 
latestPane - Variable in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
The latest time pane
LazyDbValueState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
Lazily fetched KvState using a SQL backend.
LazyDbValueState(String, boolean, ShardedConnection, DbBackendConfig, TypeSerializer<K>, TypeSerializer<N>, ValueStateDescriptor<V>) - Constructor for class org.apache.flink.contrib.streaming.state.LazyDbValueState
Constructor to initialize the LazyDbValueState the first time the job starts.
LazyDbValueState(String, boolean, ShardedConnection, DbBackendConfig, TypeSerializer<K>, TypeSerializer<N>, ValueStateDescriptor<V>, long, long) - Constructor for class org.apache.flink.contrib.streaming.state.LazyDbValueState
Initialize the LazyDbValueState from a snapshot.
lazyDestroy() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Destroys this buffer pool.
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
 
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 - 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.minicluster.FlinkMiniCluster
 
leaderRetrievalService() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
leaderRetrievalService() - Method in class org.apache.flink.yarn.ApplicationClient
 
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() - 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
 
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.
LeafExpression - Class in org.apache.flink.api.table.expressions
 
LeafExpression() - Constructor for class org.apache.flink.api.table.expressions.LeafExpression
 
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$
 
left() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.EitherDescriptor
 
left() - Method in class org.apache.flink.api.table.expressions.And
 
left() - Method in class org.apache.flink.api.table.expressions.BinaryExpression
 
left() - Method in class org.apache.flink.api.table.expressions.BitwiseAnd
 
left() - Method in class org.apache.flink.api.table.expressions.BitwiseOr
 
left() - Method in class org.apache.flink.api.table.expressions.BitwiseXor
 
left() - Method in class org.apache.flink.api.table.expressions.Div
 
left() - Method in class org.apache.flink.api.table.expressions.EqualTo
 
left() - Method in class org.apache.flink.api.table.expressions.GreaterThan
 
left() - Method in class org.apache.flink.api.table.expressions.GreaterThanOrEqual
 
left() - Method in class org.apache.flink.api.table.expressions.LessThan
 
left() - Method in class org.apache.flink.api.table.expressions.LessThanOrEqual
 
left() - Method in class org.apache.flink.api.table.expressions.Minus
 
left() - Method in class org.apache.flink.api.table.expressions.Mod
 
left() - Method in class org.apache.flink.api.table.expressions.Mul
 
left() - Method in class org.apache.flink.api.table.expressions.NotEqualTo
 
left() - Method in class org.apache.flink.api.table.expressions.Or
 
left() - Method in class org.apache.flink.api.table.expressions.Plus
 
left() - Method in class org.apache.flink.api.table.plan.Join
 
left() - Method in class org.apache.flink.api.table.plan.UnionAll
 
left() - Method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
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>) - 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.
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
 
leftTypeInfo() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
LegacyFetcher - Class in org.apache.flink.streaming.connectors.kafka.internals
This fetcher uses Kafka's low-level API to pull data from a specific set of topics and partitions.
LegacyFetcher(Map<KafkaTopicPartition, Long>, Properties, String, ClassLoader) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher
Create a LegacyFetcher instance.
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.types.StringValue
 
LessThan - Class in org.apache.flink.api.table.expressions
 
LessThan(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.LessThan
 
lessThan() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
lessThan() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
LessThan$ - Class in org.apache.flink.api.table.expressions
 
LessThan$() - Constructor for class org.apache.flink.api.table.expressions.LessThan$
 
LessThanOrEqual - Class in org.apache.flink.api.table.expressions
 
LessThanOrEqual(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.LessThanOrEqual
 
lessThanOrEqual() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
lessThanOrEqual() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
LessThanOrEqual$ - Class in org.apache.flink.api.table.expressions
 
LessThanOrEqual$() - Constructor for class org.apache.flink.api.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
 
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
 
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
A set of parameters -- theta0, theta1.
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
Compute a single BGD type update for every parameters.
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
 
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.examples.scala.TPCHQuery3Table.Lineitem
 
Lineitem$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem$
 
Lineitem$() - Constructor for class org.apache.flink.examples.scala.TPCHQuery3Table.Lineitem$
 
Link(long, long) - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.Link
 
Link(long, long) - Constructor for class org.apache.flink.examples.scala.PageRankTable.Link
 
Link$() - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.Link$
 
Link$() - Constructor for class org.apache.flink.examples.scala.PageRankTable.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
 
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
 
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.jobmanager.JobInfo
 
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
 
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.
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.runtime.fs.hdfs.HadoopFileSystem
 
listStatus(Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
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.
ListWindowBuffer<T> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
An EvictingWindowBuffer that stores elements on the Java Heap.
ListWindowBuffer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
 
ListWindowBuffer(ArrayDeque<StreamRecord<T>>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
 
ListWindowBuffer.Factory<T> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
 
Literal - Class in org.apache.flink.api.table.expressions
 
Literal(Object, TypeInformation<?>) - Constructor for class org.apache.flink.api.table.expressions.Literal
 
Literal$ - Class in org.apache.flink.api.table.expressions
 
Literal$() - Constructor for class org.apache.flink.api.table.expressions.Literal$
 
LiteralBooleanExpression(boolean) - Constructor for class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralBooleanExpression
 
LiteralDoubleExpression(double) - Constructor for class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralDoubleExpression
 
literalExpr() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
literalExpr() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
LiteralFloatExpression(float) - Constructor for class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralFloatExpression
 
LiteralIntExpression(int) - Constructor for class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralIntExpression
 
LiteralLongExpression(long) - Constructor for class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralLongExpression
 
LiteralStringExpression(String) - Constructor for class org.apache.flink.api.scala.table.ImplicitExpressionConversions.LiteralStringExpression
 
loadConfiguration(String) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Loads the configuration files from the specified directory.
loadGlobalConfigParams() - Static method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
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_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
 
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 LocalFile provides an implementation of the FileSystem interface for the local file system.
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, boolean) - Constructor for class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
LocalFlinkMiniCluster(Configuration) - Constructor for class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
LocalGetYarnClusterStatus$() - Constructor for class org.apache.flink.yarn.YarnMessages.LocalGetYarnClusterStatus$
 
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.
LocalIterations$() - Constructor for class org.apache.flink.ml.classification.SVM.LocalIterations$
 
Locality - Enum in org.apache.flink.runtime.jobmanager.scheduler
 
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
 
LocalStateHandle<T extends Serializable> - Class in org.apache.flink.runtime.state
A StateHandle that includes the operator states directly.
LocalStateHandle(T) - Constructor for class org.apache.flink.runtime.state.LocalStateHandle
 
LocalStopAMAfterJob(JobID) - Constructor for class org.apache.flink.yarn.YarnMessages.LocalStopAMAfterJob
 
LocalStopAMAfterJob$() - Constructor for class org.apache.flink.yarn.YarnMessages.LocalStopAMAfterJob$
 
LocalStopYarnSession(FinalApplicationStatus, 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.
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
 
lock(K, V, long) - 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.checkpoint.CheckpointCoordinator
Coordinator-wide lock to safeguard the checkpoint updates
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.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() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
LOG() - Method in class org.apache.flink.api.table.codegen.GenerateFilter
 
LOG() - Method in class org.apache.flink.api.table.codegen.GenerateJoin
 
LOG() - Method in class org.apache.flink.api.table.codegen.GenerateSelect
 
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.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 - Static variable in class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
 
log() - Method in interface org.apache.flink.runtime.FlinkActor
 
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() - 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() - 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.runtime.tasks.StreamTask
The logger used by the StreamTask and its subclasses
log() - Method in class org.apache.flink.yarn.ApplicationClient
 
log() - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
log() - Method in class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector$
 
log() - Static method in class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector
 
log2floor(int) - Static method in class org.apache.flink.runtime.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.runtime.util.MathUtils
Computes the logarithm of the given value to the base of 2.
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
 
logger - Static variable in class org.apache.flink.storm.api.FlinkSubmitter
 
LoggingHandler() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor.LoggingHandler
 
logic() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
logic() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
LogMessages - Interface in org.apache.flink.runtime
Mixin to add message logging if the debug log level is activated
logPartitionInfo(List<KafkaTopicPartition>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Method to log partition information.
long2Literal(long) - Method in interface org.apache.flink.api.scala.table.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_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
 
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
 
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
 
LongSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.LongSum
 
LongSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
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
 
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.
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
 
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
 
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
 
lookupKey(String, PreparedStatement, byte[], long) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Retrieve the latest value from the database for a given key and timestamp.
lookupKey(String, PreparedStatement, byte[], long) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
lookupMatch(PT) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap.Prober
 
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
LossyCounting - Class in org.apache.flink.contrib.operatorstatistics.heavyhitters
Implements Lossy Counting algorithm (Manku, G.S., Motwani, R.: Approximate frequency counts over data streams, 2002) The algorithm tracks heavy hitters in a count based fashion.
LossyCounting(double, double) - Constructor for class org.apache.flink.contrib.operatorstatistics.heavyhitters.LossyCounting
 
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$
 
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.client.FlinkYarnSessionCli
 
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.JavaTableExample
 
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[]) - Static method in class org.apache.flink.examples.java8.relational.TPCHQuery10
 
main(String[]) - Static method in class org.apache.flink.examples.java8.wordcount.WordCount
 
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.PageRankTable$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.PageRankTable
 
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.StreamingTableFilter$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.StreamingTableFilter
 
main(String[]) - Method in class org.apache.flink.examples.scala.TPCHQuery3Table$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.TPCHQuery3Table
 
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[]) - Method in class org.apache.flink.examples.scala.WordCountTable$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.WordCountTable
 
main(String[]) - Static method in class org.apache.flink.graph.examples.ConnectedComponents
 
main(String[]) - Static method in class org.apache.flink.graph.examples.EuclideanGraphWeighing
 
main(String[]) - Static method in class org.apache.flink.graph.examples.GraphMetrics
 
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.JaccardSimilarityMeasure
 
main(String[]) - Static method in class org.apache.flink.graph.examples.MusicProfiles
 
main(String[]) - Static method in class org.apache.flink.graph.examples.SingleSourceShortestPaths
 
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.GraphMetrics$
 
main(String[]) - Static method in class org.apache.flink.graph.scala.examples.GraphMetrics
 
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.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.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.connectors.twitter.TwitterStreaming
 
main(String[]) - Static method in class org.apache.flink.streaming.connectors.twitter.TwitterTopology
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.iteration.IterateExample
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.java8.wordcount.WordCount
 
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.socket.SocketTextStreamWordCount
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.twitter.TwitterStream
 
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.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.SocketTextStreamWordCount$
 
main(String[]) - Static method in class org.apache.flink.streaming.scala.examples.socket.SocketTextStreamWordCount
 
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[]) - Method in class org.apache.flink.yarn.ApplicationMaster$
 
main(String[]) - Static method in class org.apache.flink.yarn.ApplicationMaster
 
main(String[]) - Static method in class org.apache.flink.yarn.YarnTaskManagerRunner
 
makeCached() - Method in enum org.apache.flink.optimizer.dag.TempMode
 
makeCoGroupWithSolutionSet(int) - Method in class org.apache.flink.optimizer.dag.CoGroupNode
 
makeCopy(Seq<Object>) - Method in class org.apache.flink.api.table.trees.TreeNode
Creates a new copy of this expression with new children.
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.
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.
ManualWatermarkContext(StreamSource<?, ?>, Object, Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext
 
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>) - 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(I) - Method in class org.apache.flink.api.table.runtime.ExpressionSelectFunction
 
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(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, Double>) - Method in class org.apache.flink.graph.library.GSASingleSourceShortestPaths.InitVerticesMapper
 
map(Vertex<K, Double>) - 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.EdgeToTuple3Map
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.utils.NullValueEdgeMapper
 
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(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(String) - Method in class org.apache.flink.streaming.examples.join.WindowJoin.MySourceMap
 
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
 
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.
MapFunction<T,O> - Interface in org.apache.flink.api.common.functions
Base interface for Map functions.
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>) - 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
 
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
 
MAPPED_FILE_SIZE - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
mapper - Variable in class org.apache.flink.graph.GraphCsvReader
 
mapredOutputFormat - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
mapreduceOutputFormat - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
mapResultToTuple(Result) - Method in class org.apache.flink.addons.hbase.TableInputFormat
 
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.
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.
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.
markAllOutgoingConnectionsAsPipelineBreaking() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
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
 
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
 
materialize() - Method in class org.apache.flink.runtime.state.AsynchronousKvStateSnapshot
Materializes the state held by this AsynchronousKvStateSnapshot.
materialize() - Method in class org.apache.flink.runtime.state.AsynchronousStateHandle
Materializes the state held by this AsynchronousStateHandle.
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
 
MathUtils - Class in org.apache.flink.runtime.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
 
MavenForkNumberPrefixLayout - Class in org.apache.flink.util
The logging layout used to prefix each log event with the Maven fork number.
MavenForkNumberPrefixLayout() - Constructor for class org.apache.flink.util.MavenForkNumberPrefixLayout
 
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(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() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
Max - Class in org.apache.flink.api.table.expressions
 
Max(Expression) - Constructor for class org.apache.flink.api.table.expressions.Max
 
MAX() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
max() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
MAX() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
max() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
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 that gives the current maximum of the pojo 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$ - Class in org.apache.flink.api.table.expressions
 
Max$() - Constructor for class org.apache.flink.api.table.expressions.Max$
 
Max$() - Constructor for class org.apache.flink.ml.preprocessing.MinMaxScaler.Max$
 
MAX_ARITY - Static variable in class org.apache.flink.api.java.tuple.Tuple
 
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.runtime.state.filesystem.FsStateBackend
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_DURATION() - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
MAX_REGISTRATION_TIMEOUT() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
MAX_REGISTRATION_TIMEOUT() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
MAX_REGISTRATION_TIMEOUT() - Method in class org.apache.flink.yarn.ApplicationClient$
 
MAX_REGISTRATION_TIMEOUT() - Static method in class org.apache.flink.yarn.ApplicationClient
 
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 suitable network interface to use for communication
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 suitable network interface to use for communication
MAX_WATERMARK - Static variable in class org.apache.flink.streaming.api.watermark.Watermark
The watermark that signifies end-of-event-time
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(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 that gives the current maximum element of the pojo 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 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 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 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 position.
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.
maxFailedContainers() - Method in class org.apache.flink.yarn.YarnJobManager
 
maxFanIn - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
MaxKafkaMetricAccumulator - Class in org.apache.flink.streaming.connectors.kafka.internals.metrics
 
MaxKafkaMetricAccumulator(KafkaMetric) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.metrics.MaxKafkaMetricAccumulator
 
maxRegistrationDuration() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerConfiguration
 
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
 
maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.Window
 
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$() - 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
 
MemFoldingState<K,N,T,ACC> - Class in org.apache.flink.runtime.state.memory
Heap-backed partitioned FoldingState that is snapshotted into a serialized memory copy.
MemFoldingState(TypeSerializer<K>, TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Constructor for class org.apache.flink.runtime.state.memory.MemFoldingState
 
MemFoldingState(TypeSerializer<K>, TypeSerializer<N>, FoldingStateDescriptor<T, ACC>, HashMap<N, Map<K, ACC>>) - Constructor for class org.apache.flink.runtime.state.memory.MemFoldingState
 
MemFoldingState.Snapshot<K,N,T,ACC> - Class in org.apache.flink.runtime.state.memory
 
MemListState<K,N,V> - Class in org.apache.flink.runtime.state.memory
Heap-backed partitioned ListState that is snapshotted into a serialized memory copy.
MemListState(TypeSerializer<K>, TypeSerializer<N>, ListStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.memory.MemListState
 
MemListState(TypeSerializer<K>, TypeSerializer<N>, ListStateDescriptor<V>, HashMap<N, Map<K, ArrayList<V>>>) - Constructor for class org.apache.flink.runtime.state.memory.MemListState
 
MemListState.Snapshot<K,N,V> - Class in org.apache.flink.runtime.state.memory
 
memManager - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
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) - Constructor for class org.apache.flink.runtime.jobmanager.MemoryArchivist
 
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.MemoryStateBackend.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 - 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
 
memoryPerTaskManager() - Method in class org.apache.flink.yarn.YarnJobManager
 
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.
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.MemoryCheckpointOutputStream - Class in org.apache.flink.runtime.state.memory
A CheckpointStateOutputStream that writes into a byte array.
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.runtime.state.memory
Heap-backed partitioned ReducingState that is snapshotted into a serialized memory copy.
MemReducingState(TypeSerializer<K>, TypeSerializer<N>, ReducingStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.memory.MemReducingState
 
MemReducingState(TypeSerializer<K>, TypeSerializer<N>, ReducingStateDescriptor<V>, HashMap<N, Map<K, V>>) - Constructor for class org.apache.flink.runtime.state.memory.MemReducingState
 
MemReducingState.Snapshot<K,N,V> - Class in org.apache.flink.runtime.state.memory
 
MemValueState<K,N,V> - Class in org.apache.flink.runtime.state.memory
Heap-backed key/value state that is snapshotted into a serialized memory copy.
MemValueState(TypeSerializer<K>, TypeSerializer<N>, ValueStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.memory.MemValueState
 
MemValueState(TypeSerializer<K>, TypeSerializer<N>, ValueStateDescriptor<V>, HashMap<N, Map<K, V>>) - Constructor for class org.apache.flink.runtime.state.memory.MemValueState
 
MemValueState.Snapshot<K,N,V> - Class in org.apache.flink.runtime.state.memory
 
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<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<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<T, ArrayList<byte[]>>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
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(HeavyHitter) - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.CountMinHeavyHitter
 
merge(HeavyHitter) - Method in interface org.apache.flink.contrib.operatorstatistics.heavyhitters.HeavyHitter
 
merge(HeavyHitter) - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.LossyCounting
 
merge(OperatorStatistics) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatistics
 
merge(Accumulator<Object, OperatorStatistics>) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsAccumulator
 
merge(Accumulator<Integer, ArrayList<Integer>>) - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
merge(TriggerResult, TriggerResult) - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
Merges two TriggerResults.
merge(Accumulator<Void, Double>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.AvgKafkaMetricAccumulator
 
merge(Accumulator<Void, Double>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
merge(Accumulator<Void, Double>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.MaxKafkaMetricAccumulator
 
merge(Accumulator<Void, Double>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.MinKafkaMetricAccumulator
 
MERGE_ITERATION_AUX_TASKS_KEY - Static variable in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
 
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.
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.
mergedValue - Variable in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
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.
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
 
mergeWith(ParameterTool) - Method in class org.apache.flink.api.java.utils.ParameterTool
Merges two ParameterTool
MergingState<IN,OUT> - Interface in org.apache.flink.api.common.state
Base interface for partitioned state that supports adding elements and inspecting the current state of merged elements.
message() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.LeaderSessionMessage
 
message() - Method in class org.apache.flink.yarn.YarnMessages.YarnMessage
 
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.
MessageDecorator - Interface in org.apache.flink.runtime.messages
Interface for message decorators
MessageIterator<Message> - Class in org.apache.flink.graph.spargel
An iterator that returns messages.
MessageIterator() - Constructor for class org.apache.flink.graph.spargel.MessageIterator
 
messageListener() - Method in class org.apache.flink.yarn.YarnJobManager
 
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.Acknowledge$ - Class in org.apache.flink.runtime.messages
Message to signal the successful reception of another message
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
 
MessagingFunction<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.
MessagingFunction() - Constructor for class org.apache.flink.graph.spargel.MessagingFunction
 
methodName() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.ObjectMethodAccessor
 
methodOption() - Method in class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector$
 
methodOption() - Static method in class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector
 
MethodVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
metricsOption() - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
metricsOption() - Method in class org.apache.flink.ml.preprocessing.StandardScaler
 
metricsReport() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.Heartbeat
 
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(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(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() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
Min - Class in org.apache.flink.api.table.expressions
 
Min(Expression) - Constructor for class org.apache.flink.api.table.expressions.Min
 
MIN() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
min() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
MIN() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
min() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
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 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 that gives the current minimum of the pojo 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$ - Class in org.apache.flink.api.table.expressions
 
Min$() - Constructor for class org.apache.flink.api.table.expressions.Min$
 
Min$() - Constructor for class org.apache.flink.ml.preprocessing.MinMaxScaler.Min$
 
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.
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(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 that gives the current minimum element of the pojo 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 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 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 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 position.
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.
MinDistanceMessenger() - Constructor for class org.apache.flink.graph.examples.SingleSourceShortestPaths.MinDistanceMessenger
 
MinDistanceMessenger() - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths.MinDistanceMessenger
 
MINIMUM_HEAP_SIZE_MB - Static variable in class org.apache.flink.test.util.TestBaseUtils
 
MinKafkaMetricAccumulator - Class in org.apache.flink.streaming.connectors.kafka.internals.metrics
 
MinKafkaMetricAccumulator(KafkaMetric) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.metrics.MinKafkaMetricAccumulator
 
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$
 
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
 
minSplitSize - Variable in class org.apache.flink.api.common.io.FileInputFormat
The minimal split size, set by the configure() method.
Minus - Class in org.apache.flink.api.table.expressions
 
Minus(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.Minus
 
Minus$ - Class in org.apache.flink.api.table.expressions
 
Minus$() - Constructor for class org.apache.flink.api.table.expressions.Minus$
 
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.
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.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
 
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
 
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.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
 
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$
 
Mod - Class in org.apache.flink.api.table.expressions
 
Mod(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.Mod
 
Mod$ - Class in org.apache.flink.api.table.expressions
 
Mod$() - Constructor for class org.apache.flink.api.table.expressions.Mod$
 
mode - Variable in class org.apache.flink.test.util.MultipleProgramsTestBase
 
ModHashPartitioner() - Constructor for class org.apache.flink.contrib.streaming.state.ShardedConnection.ModHashPartitioner
 
MODIFIED_CONF_FILE() - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
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.ExecutionMode$
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.api.table.codegen.Indenter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Abs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.analysis.ExtractEquiJoinFields$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.And$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Avg$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.BitwiseAnd$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.BitwiseNot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.BitwiseOr$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.BitwiseXor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Cast$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Count$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Div$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.EqualTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Expression$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.GreaterThan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.GreaterThanOrEqual$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.IsNotNull$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.IsNull$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.LessThan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.LessThanOrEqual$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Literal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Max$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Min$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Minus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Mod$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Mul$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Naming$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.NopExpression$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Not$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.NotEqualTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Or$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Plus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.ResolvedFieldReference$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Substring$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.Sum$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.UnaryMinus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.expressions.UnresolvedFieldReference$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.parser.ExpressionParser$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.parser.ExpressionParser.Keyword$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.Aggregate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.As$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.ExpandAggregations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.Filter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.GroupBy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.Join$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.Root$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.Select$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.plan.UnionAll$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.runtime.ExpressionFilterFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.runtime.ExpressionJoinFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.runtime.ExpressionSelectFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.Table$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.TableConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.typeinfo.NullMaskUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.table.typeinfo.RowComparator$
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.PageRankTable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.PageRankTable.AdjacencyList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.PageRankTable.Link$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.PageRankTable.Page$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.PageRankTable.RankOutput$
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.StreamingTableFilter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.StreamingTableFilter.CarEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.TPCHQuery3Table$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.TPCHQuery3Table.Customer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.TPCHQuery3Table.Lineitem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.TPCHQuery3Table.Order$
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.examples.scala.WordCountTable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.WordCountTable.WC$
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.GraphMetrics$
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.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.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.optimization.GenericLossFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.GradientDescentL1$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.GradientDescentL2$
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.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.SimpleGradientDescent$
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.SquaredLoss$
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.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.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.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.JobClientMessages.SubmitJobDetached$
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.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.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.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.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.RequestPartitionState$
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.Acknowledge$
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.ResponseStackTraceSampleFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleSuccess$
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.NotifyWhenRegisteredAtAnyJobManager$
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.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.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.PartitionState$
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.TaskOperationResult$
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.NetworkEnvironmentConfiguration$
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.runtime.taskmanager.TaskManagerConfiguration$
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.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.socket.SocketTextStreamWordCount$
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.test.util.ForkableFlinkMiniCluster$
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.ApplicationMaster$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.ApplicationMasterBase$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector$
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.JobManagerStopped$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.LocalGetYarnClusterStatus$
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.LocalStopAMAfterJob$
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.PollYarnClusterStatus$
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.StopAMAfterJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.StopYarnSession$
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.UnregisterClient$
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.YarnMessages.YarnMessage$
Static reference to the singleton instance of this Scala object.
ModuloKeyPartitioner$() - Constructor for class org.apache.flink.ml.common.FlinkMLTools.ModuloKeyPartitioner$
 
msg - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
Mul - Class in org.apache.flink.api.table.expressions
 
Mul(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.Mul
 
Mul$ - Class in org.apache.flink.api.table.expressions
 
Mul$() - Constructor for class org.apache.flink.api.table.expressions.Mul$
 
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.streaming.runtime.streamrecord
Serializer for StreamRecord and Watermark.
MultiplexingStreamRecordSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
multiplyWith(int) - Method in class org.apache.flink.optimizer.costs.Costs
 
murmurHash(int) - Static method in class org.apache.flink.runtime.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.
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) - Constructor for class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
 
mutableTypes() - Method in interface org.apache.flink.api.scala.codegen.TypeAnalyzer
 
MyJoinFunction() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoin.MyJoinFunction
 
myName() - Method in class org.apache.flink.api.scala.InnerClosureFinder
 
MySelector() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample.MySelector
 
MySourceMap() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoin.MySourceMap
 
MySqlAdapter - Class in org.apache.flink.contrib.streaming.state
Adapter for bridging inconsistencies between the different SQL implementations.
MySqlAdapter() - Constructor for class org.apache.flink.contrib.streaming.state.MySqlAdapter
 

N

name - Variable in class org.apache.flink.api.common.operators.Operator
 
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) - Method in class org.apache.flink.api.scala.DataSet
Sets the name of the DataSet.
name() - Method in class org.apache.flink.api.table.expressions.And
 
name() - Method in class org.apache.flink.api.table.expressions.Expression
 
name() - Method in class org.apache.flink.api.table.expressions.Naming
 
name() - Method in class org.apache.flink.api.table.expressions.NopExpression
 
name() - Method in class org.apache.flink.api.table.expressions.Not
 
name() - Method in class org.apache.flink.api.table.expressions.Or
 
name() - Method in class org.apache.flink.api.table.expressions.ResolvedFieldReference
 
name() - Method in class org.apache.flink.api.table.expressions.UnresolvedFieldReference
 
name - Variable in class org.apache.flink.examples.java.misc.CollectionExecutionExample.User
 
name - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
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() - 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
 
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
 
NamedFlatFieldDescriptor(String, int, TypeInformation<?>) - Constructor for class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
names() - Method in class org.apache.flink.api.table.plan.As
 
names() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
names() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
namespaceSerializer - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
Namespace serializer
namespaceSerializer - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Serializer for the namespace
namespaceSerializer - Variable in class org.apache.flink.runtime.state.AbstractHeapState
The serializer for the namespace
namespaceSerializer - Variable in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
Namespace Serializer
namespaceSerializer - Variable in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
Namespace Serializer
Naming - Class in org.apache.flink.api.table.expressions
 
Naming(Expression, String) - Constructor for class org.apache.flink.api.table.expressions.Naming
 
Naming$ - Class in org.apache.flink.api.table.expressions
 
Naming$() - Constructor for class org.apache.flink.api.table.expressions.Naming$
 
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.
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
 
NestedKeyDiscarder<IN> - Class in org.apache.flink.python.api.functions.util
 
NestedKeyDiscarder() - Constructor for class org.apache.flink.python.api.functions.util.NestedKeyDiscarder
 
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.
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() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
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
 
NetworkEnvironment - Class in org.apache.flink.runtime.io.network
Network I/O components of each TaskManager instance.
NetworkEnvironment(ExecutionContext, FiniteDuration, NetworkEnvironmentConfiguration) - Constructor for class org.apache.flink.runtime.io.network.NetworkEnvironment
Initializes all network I/O components.
NetworkEnvironmentConfiguration - Class in org.apache.flink.runtime.taskmanager
 
NetworkEnvironmentConfiguration(int, int, MemoryType, IOManager.IOMode, Option<NettyConfig>, Tuple2<Integer, Integer>) - Constructor for class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NetworkEnvironmentConfiguration$ - Class in org.apache.flink.runtime.taskmanager
 
NetworkEnvironmentConfiguration$() - Constructor for class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration$
 
newControlFlowEdge(int, int) - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
newExecutionState() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
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
 
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
 
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
 
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
 
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 operator to the existing one.
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.jobgraph.tasks.InputSplitIterator
 
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(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(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.runtime.util.UnionIterator
 
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.SimpleStringUtils.WhitespaceTokenizer
Gets the next token from the string.
next(int) - Method in class org.apache.flink.util.XORShiftRandom
All other methods like nextInt()/nextDouble()...
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
 
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.
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.TableInputFormat
 
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(OUT) - 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(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
 
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.
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) - Constructor for class org.apache.flink.cep.nfa.NFA
 
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.
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.
nmClientOption() - Method in class org.apache.flink.yarn.YarnJobManager
 
NO_STRINGS - Static variable in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
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 - Class in org.apache.flink.api.table.explain
 
Node() - Constructor for class org.apache.flink.api.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
 
NoExpressionAggregateFunction - Class in org.apache.flink.api.table.runtime
 
NoExpressionAggregateFunction() - Constructor for class org.apache.flink.api.table.runtime.NoExpressionAggregateFunction
 
NoFetchingInput - Class in org.apache.flink.api.java.typeutils.runtime
 
NoFetchingInput(InputStream) - Constructor for class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
noMoreBlocks - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
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
 
NonKeyedWindowOperator<IN,ACC,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
Window operator for non-keyed windows.
NonKeyedWindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, WindowBufferFactory<? super IN, ACC, ? extends WindowBuffer<IN, ACC>>, AllWindowFunction<ACC, OUT, W>, Trigger<? super IN, ? super W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
Creates a new WindowOperator based on the given policies and user functions.
NonKeyedWindowOperator.Context - Class in org.apache.flink.streaming.runtime.operators.windowing
The Context is responsible for keeping track of the state of one pane.
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
A Bucketer that does not perform any rolling of files.
NonRollingBucketer() - Constructor for class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
 
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.
NonTimestampContext(StreamSource<?, ?>, Object, Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext
 
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
 
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
 
NoOpUnaryUdfOp<OUT> - Class in org.apache.flink.optimizer.util
 
NoOpUnaryUdfOp() - Constructor for class org.apache.flink.optimizer.util.NoOpUnaryUdfOp
 
NopExpression - Class in org.apache.flink.api.table.expressions
 
NopExpression() - Constructor for class org.apache.flink.api.table.expressions.NopExpression
 
NopExpression$ - Class in org.apache.flink.api.table.expressions
 
NopExpression$() - Constructor for class org.apache.flink.api.table.expressions.NopExpression$
 
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
 
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
 
NoRestartStrategyConfiguration() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
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 - Class in org.apache.flink.api.table.expressions
 
Not(Expression) - Constructor for class org.apache.flink.api.table.expressions.Not
 
Not$ - Class in org.apache.flink.api.table.expressions
 
Not$() - Constructor for class org.apache.flink.api.table.expressions.Not$
 
NotEqualTo - Class in org.apache.flink.api.table.expressions
 
NotEqualTo(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.NotEqualTo
 
notEqualTo() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
notEqualTo() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
NotEqualTo$ - Class in org.apache.flink.api.table.expressions
 
NotEqualTo$() - Constructor for class org.apache.flink.api.table.expressions.NotEqualTo$
 
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
 
notifyAvailableBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Notifies the owning SingleInputGate about an available Buffer instance.
notifyCheckpointComplete(long) - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
 
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 - 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.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.RollingSink
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
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.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
 
notifyOfCompletedCheckpoint(long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
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.
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).
notifyPartitionConsumable(JobID, ResultPartitionID) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionConsumableNotifier
 
notifySolutionSetUpdate() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
Releases the waiting thread.
notifySubpartitionConsumed() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
 
notifySubpartitionConsumed() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
NotifyWhenRegisteredAtAnyJobManager$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.NotifyWhenRegisteredAtAnyJobManager$
 
notLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
NULL_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
NullAwareComparator<T> - Class in org.apache.flink.api.table.typeinfo
Null-aware comparator that wraps a comparator which does not support null references.
NullAwareComparator(TypeComparator<T>, boolean) - Constructor for class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
nullCheck() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
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)
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.
NullMaskUtils - Class in org.apache.flink.api.table.typeinfo
 
NullMaskUtils() - Constructor for class org.apache.flink.api.table.typeinfo.NullMaskUtils
 
NullMaskUtils$ - Class in org.apache.flink.api.table.typeinfo
 
NullMaskUtils$() - Constructor for class org.apache.flink.api.table.typeinfo.NullMaskUtils$
 
NullSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
 
nullTerm() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.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 - 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.
NullValueEdgeMapper<K,EV> - Class in org.apache.flink.graph.utils
 
NullValueEdgeMapper() - Constructor for class org.apache.flink.graph.utils.NullValueEdgeMapper
 
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_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.api.table.parser.ExpressionParser$
 
numberLiteral() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
numberOfEdges() - Method in class org.apache.flink.graph.Graph
 
numberOfEdges() - Method in class org.apache.flink.graph.scala.Graph
 
numberOfSlots() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager
 
numberOfSlots() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
numberOfSlots() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerConfiguration
 
numberOfVertices() - Method in class org.apache.flink.graph.Graph
 
numberOfVertices() - Method in class org.apache.flink.graph.scala.Graph
 
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.
numCheckpointsToKeep - Variable in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
numCols() - Method in class org.apache.flink.ml.math.DenseMatrix
 
numCols() - Method in interface org.apache.flink.ml.math.Matrix
Number of columns
numCols() - Method in class org.apache.flink.ml.math.SparseMatrix
 
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
 
NumFactors$() - Constructor for class org.apache.flink.ml.recommendation.ALS.NumFactors$
 
numHashFunctions - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
 
numJobManagers() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
numLeadingNormalizableKeys - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
numNetworkBuffers() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
numOfCars() - Method in class org.apache.flink.examples.scala.StreamingTableFilter$
 
numOfCars() - Static method in class org.apache.flink.examples.scala.StreamingTableFilter
 
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
 
numPendingRequests() - Method in class org.apache.flink.yarn.YarnJobManager
 
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.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
 
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.
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.YarnJobManager
 
numTaskManagers() - Method in class org.apache.flink.yarn.YarnMessages.ApplicationMasterStatus
 
numWriteBuffersToCluster - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 

O

ObjectArrayTypeInfo<T,C> - Class in org.apache.flink.api.java.typeutils
 
ObjectFieldAccessor(String) - Constructor for class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.ObjectFieldAccessor
 
ObjectMethodAccessor(String) - Constructor for class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.ObjectMethodAccessor
 
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.
ODD_STREAM - Static variable in class org.apache.flink.storm.split.operators.RandomSpout
 
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(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) - 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) - 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.TumblingEventTimeWindows
Creates a new TumblingEventTimeWindows 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.TumblingProcessingTimeWindows
Creates a new TumblingProcessingTimeWindows 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.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(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(Time) - 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(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
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()).
OFFSET_NOT_SET - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Magic number to define an unset offset.
OffsetHandler - Interface in org.apache.flink.streaming.connectors.kafka.internals
The offset handler is responsible for locating the initial partition offsets where the source should start reading, as well as committing offsets from completed checkpoints.
offsetsState - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
The offsets of the last returned elements
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.
onAvailableBuffer(InputChannel) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
onBuffer(Buffer, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
onCancelCheckpoint(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Callback on cancellation of a checkpoint.
onCancelCheckpoint(long) - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
 
onCompletedCheckpoint(CompletedCheckpoint) - Method in interface org.apache.flink.runtime.checkpoint.stats.CheckpointStatsTracker
Callback on a completed checkpoint.
onCompletedCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.stats.DisabledCheckpointStatsTracker
 
onCompletedCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.stats.SimpleCheckpointStatsTracker
 
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.YarnJobManager.AMRMClientAsyncHandler
 
onContainersCompleted(List<ContainerStatus>) - Method in class org.apache.flink.yarn.YarnJobManager.AMRMClientAsyncHandler
 
onDynamicPath - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
one(T1) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
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, 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.NonKeyedWindowOperator.Context
 
onElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onEmptyBuffer(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
onError(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
onError(Throwable) - Method in class org.apache.flink.yarn.YarnJobManager.AMRMClientAsyncHandler
 
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(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(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
onEventTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onFailedPartitionRequest() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
onFullyAcknowledgedCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Callback on full acknowledgement of a checkpoint.
onFullyAcknowledgedCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
 
onNodesUpdated(List<NodeReport>) - Method in class org.apache.flink.yarn.YarnJobManager.AMRMClientAsyncHandler
 
onNotification() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
onNotification() - Method in interface org.apache.flink.runtime.util.event.NotificationListener
 
onPartitionStateUpdate(IntermediateDataSetID, IntermediateResultPartitionID, ExecutionState) - Method in class org.apache.flink.runtime.taskmanager.Task
Answer to a partition state check issued after a failed partition request.
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.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
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.process.ProcessReaper
 
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.
onShutdown() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Callback on shutdown of the coordinator.
onShutdown() - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
 
onShutdownRequest() - Method in class org.apache.flink.yarn.YarnJobManager.AMRMClientAsyncHandler
 
open(TableInputSplit) - Method in class org.apache.flink.addons.hbase.TableInputFormat
 
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.
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.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(Configuration) - Method in class org.apache.flink.api.table.runtime.ExpressionAggregateFunction
 
open(Configuration) - Method in class org.apache.flink.api.table.runtime.ExpressionFilterFunction
 
open(Configuration) - Method in class org.apache.flink.api.table.runtime.ExpressionJoinFunction
 
open(Configuration) - Method in class org.apache.flink.api.table.runtime.ExpressionSelectFunction
 
open() - Method in class org.apache.flink.cep.operator.CEPPatternOperator
 
open() - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
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(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
Reads the parameters from a broadcast variable into a collection.
open(int, int) - Method in class org.apache.flink.graph.examples.utils.ExampleUtils.PrintingOutputFormatWithMessage
 
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(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(String) - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
 
open(String) - 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(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
 
open() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
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.FileSourceFunction
 
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.MessageAcknowledgingSourceBase
 
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
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
 
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.
open() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
open() - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
 
open() - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
 
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.ScalaAllWindowFunctionWrapper
 
open(Configuration) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunctionWrapper
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
Initializes the connection to Elasticsearch by either creating an embedded Node and retrieving the Client from it or by creating a TransportClient.
open(Configuration) - Method in class org.apache.flink.streaming.connectors.flume.FlumeSink
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
 
open(FSDataOutputStream) - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
open(FSDataOutputStream) - Method in class org.apache.flink.streaming.connectors.fs.StringWriter
 
open(FSDataOutputStream) - 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.FlinkKafkaConsumer08
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Initializes the connection to Kafka.
open(int, int, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FixedPartitioner
 
open(int, int, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaPartitioner
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(Configuration) - Method in class org.apache.flink.streaming.examples.join.WindowJoin.SalarySource
 
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.ExtractTimestampsOperator
Deprecated.
 
open() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
 
open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
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.
openFunction(Function, Configuration) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
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.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.
operation() - Method in class org.apache.flink.api.table.Table
 
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
 
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> - 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, ?>, StreamOperator<OUT>, AccumulatorRegistry.Reporter) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
OperatorCheckpointStats - Class in org.apache.flink.runtime.checkpoint.stats
Statistics for a specific checkpoint per operator.
OperatorCheckpointStats(long, long, long, long, long[][]) - Constructor for class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
Creates a checkpoint statistic for an operator.
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
 
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
 
OperatorState<T> - Interface in org.apache.flink.api.common.state
Deprecated.
OperatorState has been replaced by ValueState.
OperatorStatistics - Class in org.apache.flink.contrib.operatorstatistics
Data structure that encapsulates statistical information of data that has only been processed by one pass This statistical information is meant to help determine the distribution of the data that has been processed in an operator so that we can determine if it is necessary to repartition the data The statistics to be gathered are configurable and represented by a OperatorStatisticsConfig object.
OperatorStatistics(OperatorStatisticsConfig) - Constructor for class org.apache.flink.contrib.operatorstatistics.OperatorStatistics
 
OperatorStatisticsAccumulator - Class in org.apache.flink.contrib.operatorstatistics
This accumulator wraps the class OperatorStatistics to track estimated values for count distinct and heavy hitters.
OperatorStatisticsAccumulator() - Constructor for class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsAccumulator
 
OperatorStatisticsAccumulator(OperatorStatisticsConfig) - Constructor for class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsAccumulator
 
OperatorStatisticsConfig - Class in org.apache.flink.contrib.operatorstatistics
Configures the behavior of an OperatorStatistics instance.
OperatorStatisticsConfig() - Constructor for class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
OperatorStatisticsConfig(boolean) - Constructor for class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
OperatorStatisticsConfig(OperatorStatisticsConfig.CountDistinctAlgorithm, OperatorStatisticsConfig.HeavyHitterAlgorithm) - Constructor for class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
OperatorStatisticsConfig.CountDistinctAlgorithm - Enum in org.apache.flink.contrib.operatorstatistics
 
OperatorStatisticsConfig.HeavyHitterAlgorithm - Enum in org.apache.flink.contrib.operatorstatistics
 
OperatorTranslation - Class in org.apache.flink.api.java.operators
 
OperatorTranslation() - Constructor for class org.apache.flink.api.java.operators.OperatorTranslation
 
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>>) - Method in class org.apache.flink.ml.optimization.Solver
Provides a solution for the given optimization problem
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 - 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, double, double, double, LossFunction, LearningRateMethod.LearningRateMethodTrait) - Method in class org.apache.flink.ml.optimization.GradientDescent
 
optimizeWithoutConvergenceCriterion(DataSet<LabeledVector>, DataSet<WeightVector>, int, 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
 
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
 
OptionsFactory - Interface in org.apache.flink.contrib.streaming.state
A factory for Options to be passed to the RocksDBStateBackend.
OptionType - Enum in org.apache.flink.api.java.utils
Types the parameters of managed with RequiredParameters can take.
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 - Class in org.apache.flink.api.table.expressions
 
Or(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.Or
 
Or$ - Class in org.apache.flink.api.table.expressions
 
Or$() - Constructor for class org.apache.flink.api.table.expressions.Or$
 
Order - Enum in org.apache.flink.api.common.operators
Enumeration representing order.
order() - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
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(long, long, String, long) - Constructor for class org.apache.flink.examples.scala.TPCHQuery3Table.Order
 
order - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
Order$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Order$
 
Order$() - Constructor for class org.apache.flink.examples.scala.TPCHQuery3Table.Order$
 
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.examples.scala.TPCHQuery3Table.Order
 
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.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 Key<?>>, Order) - Constructor for class org.apache.flink.api.common.operators.Ordering
 
orders - Variable in class org.apache.flink.api.common.operators.Ordering
 
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.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.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.table - package org.apache.flink.api.java.table
Table API (Java)
TableEnvironment can be used to create a Table from a DataSet or DataStream.
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.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.operators - package org.apache.flink.api.scala.operators
 
org.apache.flink.api.scala.table - package org.apache.flink.api.scala.table
 
org.apache.flink.api.scala.typeutils - package org.apache.flink.api.scala.typeutils
 
org.apache.flink.api.table - package org.apache.flink.api.table
Table API
This package contains the generic part of the Table API.
org.apache.flink.api.table.codegen - package org.apache.flink.api.table.codegen
 
org.apache.flink.api.table.explain - package org.apache.flink.api.table.explain
 
org.apache.flink.api.table.expressions - package org.apache.flink.api.table.expressions
 
org.apache.flink.api.table.expressions.analysis - package org.apache.flink.api.table.expressions.analysis
 
org.apache.flink.api.table.parser - package org.apache.flink.api.table.parser
 
org.apache.flink.api.table.plan - package org.apache.flink.api.table.plan
 
org.apache.flink.api.table.runtime - package org.apache.flink.api.table.runtime
 
org.apache.flink.api.table.trees - package org.apache.flink.api.table.trees
 
org.apache.flink.api.table.typeinfo - package org.apache.flink.api.table.typeinfo
 
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.client - package org.apache.flink.client
 
org.apache.flink.client.cli - package org.apache.flink.client.cli
 
org.apache.flink.client.program - package org.apache.flink.client.program
 
org.apache.flink.configuration - package org.apache.flink.configuration
 
org.apache.flink.contrib.operatorstatistics - package org.apache.flink.contrib.operatorstatistics
 
org.apache.flink.contrib.operatorstatistics.heavyhitters - package org.apache.flink.contrib.operatorstatistics.heavyhitters
 
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.examples.java - package org.apache.flink.examples.java
 
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.java8.relational - package org.apache.flink.examples.java8.relational
 
org.apache.flink.examples.java8.wordcount - package org.apache.flink.examples.java8.wordcount
 
org.apache.flink.examples.scala - package org.apache.flink.examples.scala
 
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.examples - package org.apache.flink.graph.examples
 
org.apache.flink.graph.examples.data - package org.apache.flink.graph.examples.data
 
org.apache.flink.graph.examples.utils - package org.apache.flink.graph.examples.utils
 
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.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.utils - package org.apache.flink.graph.utils
 
org.apache.flink.graph.validation - package org.apache.flink.graph.validation
 
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.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.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.metrics.distances - package org.apache.flink.ml.metrics.distances
 
org.apache.flink.ml.optimization - package org.apache.flink.ml.optimization
 
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.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.stats - package org.apache.flink.runtime.checkpoint.stats
 
org.apache.flink.runtime.client - package org.apache.flink.runtime.client
 
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.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.instance - package org.apache.flink.runtime.instance
 
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.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.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.plugable - package org.apache.flink.runtime.plugable
 
org.apache.flink.runtime.process - package org.apache.flink.runtime.process
 
org.apache.flink.runtime.security - package org.apache.flink.runtime.security
 
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.memory - package org.apache.flink.runtime.state.memory
 
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.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.yarn - package org.apache.flink.runtime.yarn
 
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.co - package org.apache.flink.streaming.api.functions.co
 
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.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.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.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.elasticsearch - package org.apache.flink.streaming.connectors.elasticsearch
 
org.apache.flink.streaming.connectors.flume - package org.apache.flink.streaming.connectors.flume
 
org.apache.flink.streaming.connectors.fs - package org.apache.flink.streaming.connectors.fs
 
org.apache.flink.streaming.connectors.json - package org.apache.flink.streaming.connectors.json
 
org.apache.flink.streaming.connectors.kafka - package org.apache.flink.streaming.connectors.kafka
 
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.kafka.util - package org.apache.flink.streaming.connectors.kafka.util
 
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.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.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.java8.wordcount - package org.apache.flink.streaming.examples.java8.wordcount
 
org.apache.flink.streaming.examples.join - package org.apache.flink.streaming.examples.join
 
org.apache.flink.streaming.examples.join.util - package org.apache.flink.streaming.examples.join.util
 
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.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.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.buffers - package org.apache.flink.streaming.runtime.operators.windowing.buffers
 
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.tasks - package org.apache.flink.streaming.runtime.tasks
This package contains classes that realize streaming tasks.
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.keys - package org.apache.flink.streaming.util.keys
 
org.apache.flink.streaming.util.serialization - package org.apache.flink.streaming.util.serialization
 
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.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
 
otherID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
out - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
OutBlockInformation(int[], 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
 
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
 
output(OutputFormat<T>) - Method in class org.apache.flink.api.java.DataSet
Emits a DataSet using an OutputFormat.
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 - 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.
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
 
outputFields() - Method in class org.apache.flink.api.table.plan.Aggregate
 
outputFields() - Method in class org.apache.flink.api.table.plan.As
 
outputFields() - Method in class org.apache.flink.api.table.plan.Filter
 
outputFields() - Method in class org.apache.flink.api.table.plan.GroupBy
 
outputFields() - Method in class org.apache.flink.api.table.plan.Join
 
outputFields() - Method in class org.apache.flink.api.table.plan.PlanNode
 
outputFields() - Method in class org.apache.flink.api.table.plan.Root
 
outputFields() - Method in class org.apache.flink.api.table.plan.Select
 
outputFields() - Method in class org.apache.flink.api.table.plan.UnionAll
 
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() - 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.
OutputSelectorWrapper<OUT> - Interface in org.apache.flink.streaming.api.collector.selector
 
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
 
overflowSegments - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
overflowSegments - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
overwriteRecordAt(long, T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
Deprecated.

P

p() - Method in class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric
 
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(long, double) - Constructor for class org.apache.flink.examples.scala.PageRankTable.Page
 
Page$() - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.Page$
 
Page$() - Constructor for class org.apache.flink.examples.scala.PageRankTable.Page$
 
pageId() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.Page
 
pageId() - Method in class org.apache.flink.examples.scala.PageRankTable.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> - Class in org.apache.flink.graph.library
This is an implementation of a simple PageRank algorithm, using a scatter-gather iteration.
PageRank(double, int) - Constructor for class org.apache.flink.graph.library.PageRank
Creates an instance of the PageRank algorithm.
PageRank(double, long, int) - Constructor for class org.apache.flink.graph.library.PageRank
Creates an instance of the PageRank algorithm.
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.library
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.VertexRankUpdater<K> - Class in org.apache.flink.graph.library
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
 
PageRankTable - Class in org.apache.flink.examples.scala
A basic implementation of the Page Rank algorithm using a bulk iteration.
PageRankTable() - Constructor for class org.apache.flink.examples.scala.PageRankTable
 
PageRankTable$ - Class in org.apache.flink.examples.scala
A basic implementation of the Page Rank algorithm using a bulk iteration.
PageRankTable$() - Constructor for class org.apache.flink.examples.scala.PageRankTable$
 
PageRankTable.AdjacencyList - Class in org.apache.flink.examples.scala
 
PageRankTable.AdjacencyList$ - Class in org.apache.flink.examples.scala
 
PageRankTable.Link - Class in org.apache.flink.examples.scala
 
PageRankTable.Link$ - Class in org.apache.flink.examples.scala
 
PageRankTable.Page - Class in org.apache.flink.examples.scala
 
PageRankTable.Page$ - Class in org.apache.flink.examples.scala
 
PageRankTable.RankOutput - Class in org.apache.flink.examples.scala
 
PageRankTable.RankOutput$ - Class in org.apache.flink.examples.scala
 
Pair<U extends Key<U>,V extends Key<V>> - Class in org.apache.flink.types
Generic pair base type.
Pair() - Constructor for class org.apache.flink.types.Pair
Initializes both encapsulated pair elements with empty objects.
Pair(U, V) - Constructor for class org.apache.flink.types.Pair
Initializes the encapsulated pair elements with the provided values.
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.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() - Method in interface org.apache.flink.test.util.FlinkTestBase
 
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.
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.ml.common
Base trait for parameter keys
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.
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() - Method in interface org.apache.flink.ml.common.WithParameters
 
ParameterTool - Class in org.apache.flink.api.java.utils
This class provides simple utility methods for reading and parsing program arguments from different sources
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$
 
parent - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
The parent partition this subpartition belongs to.
parentID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
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) - Method in class org.apache.flink.streaming.connectors.json.JSONParser
Parse the JSON code passed to the constructor to find the given key.
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.
parseCancelCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
parsedValues - Variable in class org.apache.flink.api.java.io.CsvInputFormat
 
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.api.table.parser.ExpressionParser$
 
parseExpression(String) - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
parseExpressionList(String) - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
parseExpressionList(String) - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
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
Parses the value of a field from the byte array.
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[], 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
 
parseInfoCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
parseListCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
parseMap(String) - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
parseMap(String) - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
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.
parseParameters(String[]) - Method in class org.apache.flink.examples.scala.StreamingTableFilter$
 
parseParameters(String[]) - Static method in class org.apache.flink.examples.scala.StreamingTableFilter
 
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.
parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
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
 
parseTaskManagerConfiguration(Configuration, String, boolean) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Utility method to extract TaskManager config parameters from the configuration and to sanity check them.
parseTaskManagerConfiguration(Configuration, String, boolean) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Utility method to extract TaskManager config parameters from the configuration and to sanity check them.
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, InstanceConnectionInfo, 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(Object, int) - Method in class org.apache.flink.streaming.connectors.kafka.internals.PartitionerWrapper
 
partition(T, byte[], byte[], int) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FixedPartitioner
 
partition(T, byte[], byte[], int) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaPartitioner
 
partitionBuffers - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
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>) - 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(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>) - 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, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
 
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.FlinkKafkaProducerBase
User-provided partitioner for assigning an object to a Kafka partition.
PartitionerWrapper - Class in org.apache.flink.streaming.connectors.kafka.internals
Hacky wrapper to send an object instance through a Properties - map.
PartitionerWrapper(VerifiableProperties) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.PartitionerWrapper
 
partitionId - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
partitionId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionState
 
partitionId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ScheduleOrUpdateConsumers
 
partitionId() - Method in class org.apache.flink.runtime.messages.TaskMessages.PartitionState
 
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, 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
 
PartitionRequestClient - Class in org.apache.flink.runtime.io.network.netty
Partition request client for remote partition requests.
partitionRequestInitialAndMaxBackoff() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
partitions - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Array with the partition ids of the given topicId The size of this array is the number of partitions
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
 
PartitionState(ExecutionAttemptID, IntermediateDataSetID, IntermediateResultPartitionID, ExecutionState) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.PartitionState
 
PartitionState$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.PartitionState$
 
PartitionStateChecker - Interface in org.apache.flink.runtime.io.network.netty
 
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
 
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
 
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_HADOOP_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
Path to Hadoop configuration
pattern(DataStream<T>, Pattern<T, ?>) - Static method in class org.apache.flink.cep.CEP
Transforms a DataStream into a PatternStream.
Pattern<T,F extends T> - Class in org.apache.flink.cep.pattern
Base class for a pattern definition.
Pattern(String, Pattern<T, ?>) - Constructor for class org.apache.flink.cep.pattern.Pattern
 
PatternFlatSelectFunction<IN,OUT> - Interface in org.apache.flink.cep
Base interface for a pattern select 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.
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.
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>) - Constructor for class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
pendingCheckpoints - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Data for pending but uncommitted checkpoints
performCheckpoint(long, long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
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.
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$
 
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.
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
 
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.
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.api.table.explain
 
PlanJsonParser() - Constructor for class org.apache.flink.api.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.api.table.plan
Base class for all Table API operations.
PlanNode() - Constructor for class org.apache.flink.api.table.plan.PlanNode
 
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
 
PlanTranslator - Class in org.apache.flink.api.table.plan
Base class for translators that transform the logical plan in a Table to an executable Flink plan and also for creating a Table from a DataSet or DataStream.
PlanTranslator() - Constructor for class org.apache.flink.api.table.plan.PlanTranslator
 
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 - Class in org.apache.flink.api.table.expressions
 
Plus(Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.Plus
 
Plus$ - Class in org.apache.flink.api.table.expressions
 
Plus$() - Constructor for class org.apache.flink.api.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
 
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.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
 
PollingThread(YarnClient, ApplicationId) - Constructor for class org.apache.flink.yarn.FlinkYarnCluster.PollingThread
 
pollingTimer() - Method in class org.apache.flink.yarn.ApplicationClient
 
PollYarnClusterStatus$() - Constructor for class org.apache.flink.yarn.YarnMessages.PollYarnClusterStatus$
 
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
 
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 - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
port() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ResponseWebMonitorPort
 
postParameters() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function tells which post parameters are used by the endpoint.
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
 
PostPassUtils - Class in org.apache.flink.optimizer.postpass
 
PostPassUtils() - Constructor for class org.apache.flink.optimizer.postpass.PostPassUtils
 
postStop() - Method in class org.apache.flink.runtime.client.JobClientActor
 
postStop() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
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
 
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.spargel.MessagingFunction
This method is executed one per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
This method is executed one per superstep after the vertex update 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(T) - Method in interface org.apache.flink.util.Visitor
 
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.
PredeterminedInputSplitAssigner(List<LocatableInputSplit>[]) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionJobVertex.PredeterminedInputSplitAssigner
 
predicate() - Method in class org.apache.flink.api.table.plan.Filter
 
PredicateAnalyzer - Class in org.apache.flink.api.table.expressions.analysis
Analyzer for predicates, i.e.
PredicateAnalyzer(Seq<Tuple2<String, TypeInformation<?>>>) - Constructor for class org.apache.flink.api.table.expressions.analysis.PredicateAnalyzer
 
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(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(Integer) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
 
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
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
 
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
 
prepareCheckpointInsert(String, Connection) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Checkpoints will be inserted in the database using prepared statements.
prepareCheckpointInsert(String, Connection) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
prepareForArchiving() - Method in class org.apache.flink.runtime.executiongraph.Execution
This method cleans fields that are irrelevant for the archived execution attempt.
prepareForArchiving() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
This method cleans fields that are irrelevant for the archived execution attempt.
prepareForArchiving() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
This method cleans fields that are irrelevant for the archived execution attempt.
prepareForArchiving() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
This method cleans fields that are irrelevant for the archived execution attempt.
prepareKeyLookup(String) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Prepare the statement that will be used to lookup keys from the database.
prepareKeyLookup(String) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
prepareKVCheckpointInsert(String) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Prepare the the statement that will be used to insert key-value pairs in the database.
prepareKVCheckpointInsert(String) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
prepareNextPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
prepareNextPartition() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
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
 
prepareStatement(String) - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
preStart() - Method in class org.apache.flink.runtime.client.JobClientActor
 
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
 
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.spargel.MessagingFunction
This method is executed one per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
This method is executed one per superstep before the vertex update function is invoked for each vertex.
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(T) - Method in interface org.apache.flink.util.Visitor
 
primitive(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
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, ...).
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
 
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() - 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() - 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).
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.
PrintingOutputFormatWithMessage() - Constructor for class org.apache.flink.graph.examples.utils.ExampleUtils.PrintingOutputFormatWithMessage
Instantiates a printing output format that prints to standard out.
PrintingOutputFormatWithMessage(String) - Constructor for class org.apache.flink.graph.examples.utils.ExampleUtils.PrintingOutputFormatWithMessage
 
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) - 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).
printResult(DataSet, String) - Static method in class org.apache.flink.graph.examples.utils.ExampleUtils
 
PrintSampleStream - Class in org.apache.flink.storm.print
Prints incoming tweets.
PrintSampleStream() - Constructor for class org.apache.flink.storm.print.PrintSampleStream
 
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
 
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() - 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
 
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
 
process(T, long) - Method in class org.apache.flink.cep.nfa.NFA
Processes the next input event.
process(Object) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatistics
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.cep.operator.AbstractCEPPatternOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
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(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.StreamCounter
 
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
 
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.runtime.operators.ExtractTimestampsOperator
Deprecated.
 
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
 
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.NonKeyedWindowOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
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 interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes one element that arrived on the first input of this two-input operator.
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 interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes one element that arrived on the second input of this two-input operator.
processEvent(NFA<IN>, IN, long) - Method in class org.apache.flink.cep.operator.AbstractCEPPatternOperator
Process the given event by giving it to the NFA and outputting the produced set of matched event sequences.
processingTimeTimer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
processingTimeTimers - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Processing time timers that are currently in-flight.
processingTimeTimersQueue - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
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(OneInputStreamOperator<IN, ?>, Object) - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
processInput(TwoInputStreamOperator<IN1, IN2, ?>, Object) - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
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
 
processTriggerResult(TriggerResult, K, W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
processTriggerResult(TriggerResult, K, W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
processUnmatchedBuildIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
processWatermark(Watermark) - Method in class org.apache.flink.cep.operator.CEPPatternOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.storm.wrappers.BoltWrapper
 
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.StreamCounter
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamFilter
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduce
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamMap
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamProject
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamSink
 
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
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
processWatermark1(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
processWatermark1(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
 
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.co.CoStreamFlatMap
 
processWatermark2(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
 
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.
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.
product() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
product() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
ProductAccessor(int) - Constructor for class org.apache.flink.api.table.codegen.ExpressionCodeGenerator.ProductAccessor
 
productArity() - Method in class org.apache.flink.api.table.Row
 
productElement(int) - Method in class org.apache.flink.api.table.Row
 
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.
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
 
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.
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
 
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.
Projection(DataSet<T>, int[]) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator.Projection
 
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
 
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
 
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.
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.
pushDownPages() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
put(K, V, long, K, V, long, 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(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(T) - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Adds a buffer to a PriorityQueue in log(size) time.
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(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) - Method in class org.apache.flink.storm.util.StormConfig
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.flink.types.MapValue
 
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
 
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(Boolean, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
putNormalizedKey(Byte, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
putNormalizedKey(Character, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
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(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(Integer, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
putNormalizedKey(Long, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
putNormalizedKey(Short, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
putNormalizedKey(String, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
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 an 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.PojoComparator
 
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(T, MemorySegment, int, int) - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
putNormalizedKey(Row, MemorySegment, int, int) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.SavepointStore
 
putState(T) - Method in interface org.apache.flink.runtime.checkpoint.StateStore
Puts an object into the store and returns the (logical) path to it.
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
 
PythonCoGroup<IN1,IN2,OUT> - Class in org.apache.flink.python.api.functions
CoGroupFunction that uses a python script.
PythonCoGroup(int, TypeInformation<OUT>) - Constructor for class org.apache.flink.python.api.functions.PythonCoGroup
 
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(int, TypeInformation<OUT>) - Constructor for class org.apache.flink.python.api.functions.PythonMapPartition
 
PythonOperationInfo - Class in org.apache.flink.python.api
 
PythonOperationInfo(PythonPlanStreamer) - Constructor for class org.apache.flink.python.api.PythonOperationInfo
 
PythonOperationInfo.AggregationEntry - Class in org.apache.flink.python.api
 
PythonOperationInfo.DatasizeHint - Enum in org.apache.flink.python.api
 
PythonPlanBinder - Class in org.apache.flink.python.api
This class allows the execution of a Flink plan written in python.
PythonPlanBinder() - 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() - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
PythonReceiver - Class in org.apache.flink.python.api.streaming.data
This class is used to read data from memory-mapped files.
PythonReceiver(boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonReceiver
 
PythonSender<IN> - Class in org.apache.flink.python.api.streaming.data
General-purpose class to write data to memory-mapped files.
PythonSender() - Constructor for class org.apache.flink.python.api.streaming.data.PythonSender
 
PythonStreamer - 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, int, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonStreamer
 

Q

queue - Variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
queues - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
The queue of empty buffer that can be used for reading;
queueSize - Variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
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
 
quoteCharacter - Variable in class org.apache.flink.api.java.io.CsvReader
 

R

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
 
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
 
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
 
RandomSpout - Class in org.apache.flink.storm.split.operators
 
RandomSpout(boolean, long) - Constructor for class org.apache.flink.storm.split.operators.RandomSpout
 
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
 
rank() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.Page
 
rank() - Method in class org.apache.flink.examples.scala.PageRankTable.Page
 
rank() - Method in class org.apache.flink.examples.scala.PageRankTable.RankOutput
 
RankAssigner(double) - Constructor for class org.apache.flink.examples.java.graph.PageRank.RankAssigner
 
RankMessenger(long) - Constructor for class org.apache.flink.graph.library.PageRank.RankMessenger
 
RankOutput(double, long[]) - Constructor for class org.apache.flink.examples.scala.PageRankTable.RankOutput
 
RankOutput$() - Constructor for class org.apache.flink.examples.scala.PageRankTable.RankOutput$
 
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
 
Rating(int, int, 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
 
reachedEnd() - Method in class org.apache.flink.addons.hbase.TableInputFormat
 
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.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
 
read(byte[], int, int) - Method in class org.apache.flink.api.avro.FSDataInputStreamWrapper
 
read(DataInputView) - Method in class org.apache.flink.api.common.distributions.SimpleDistribution
 
read(DataInputView) - Method in class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
 
read(DataInputView) - Method in class org.apache.flink.api.common.distributions.UniformDoubleDistribution
 
read(DataInputView) - Method in class org.apache.flink.api.common.distributions.UniformIntegerDistribution
 
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(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() - 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<Schema>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
 
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.configuration.Configuration
 
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(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.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(DataInputView) - Method in class org.apache.flink.runtime.instance.InstanceConnectionInfo
 
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.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.operators.util.TaskConfig.DelegatingConfiguration
 
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(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
read(byte[]) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
read(DataInputView) - Method in class org.apache.flink.runtime.util.SerializableArrayList
 
read(DataInputView) - Method in class org.apache.flink.runtime.util.SerializableHashMap
 
read(DataInputView) - Method in class org.apache.flink.runtime.util.SerializableHashSet
 
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.Pair
 
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(DataInputView) - Method in class org.apache.flink.util.AbstractID
 
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
 
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
 
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 given file with the given imput format.
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.
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
Creates a data stream that contains the contents of file created while system watches the given path.
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.
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.runtime.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
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, JobConf, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from the given 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[]) - Method in class org.apache.flink.api.table.typeinfo.NullMaskUtils$
 
readIntoAndCopyNullMask(int, DataInputView, DataOutputView, boolean[]) - Static method in class org.apache.flink.api.table.typeinfo.NullMaskUtils
 
readIntoNullMask(int, DataInputView, boolean[]) - Method in class org.apache.flink.api.table.typeinfo.NullMaskUtils$
 
readIntoNullMask(int, DataInputView, boolean[]) - Static method in class org.apache.flink.api.table.typeinfo.NullMaskUtils
 
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
 
readSequenceFile(Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from SequenceFileInputFormat A JobConf with the given inputPath is created.
readSequenceFile(Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from SequenceFileInputFormat A JobConf with the given inputPath is created.
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.
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
 
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
Creates a data stream that represents the Strings produced by reading the given file line wise.
readTextFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream that represents the Strings produced by reading the given file line wise.
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(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.PojoComparator
 
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(T, DataInputView) - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
readWithKeyDenormalization(Row, DataInputView) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
reason() - Method in class org.apache.flink.runtime.messages.Messages.Disconnect
 
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() - 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() - Method in interface org.apache.flink.runtime.FlinkActor
 
receive() - Method in interface org.apache.flink.runtime.LeaderSessionMessageFilter
 
receive() - Method in interface org.apache.flink.runtime.LogMessages
 
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 and returns whether the message was associated with a pending checkpoint.
receiver - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
receiver - Variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
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>) - Constructor for class org.apache.flink.runtime.io.network.api.reader.RecordReader
 
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
 
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>, boolean) - 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.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
 
recoverJobGraphs() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
recoverJobGraphs() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Returns a list of all submitted JobGraph instances.
recoverJobGraphs() - 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$
 
RECOVERY_JOB_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
The time before the JobManager recovers persisted jobs
RECOVERY_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Ports used by the job manager if not in standalone recovery mode
RECOVERY_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Defines recovery mode used for the cluster execution ("standalone", "zookeeper")
recoveryMode() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
RecoveryMode - Enum in org.apache.flink.runtime.jobmanager
Recovery mode for Flink's cluster execution.
recoveryMode() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
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(Iterable<T>, Collector<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(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>) - 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(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(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator.AggregatingUdf
 
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.api.table.runtime.ExpressionAggregateFunction
 
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.api.table.runtime.NoExpressionAggregateFunction
 
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(Iterable<Edge<String, Integer>>, Collector<Edge<String, NullValue>>) - Method in class org.apache.flink.graph.examples.MusicProfiles.CreateSimilarUserEdges
 
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>) - 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(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(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(Tuple2<Long, Long>, Tuple2<Long, Long>) - Method in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingReducer
 
ReduceApplyAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
 
ReduceApplyAllWindowFunction(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
 
ReduceApplyWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
 
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.
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>) - 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.
ReduceIterableAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
 
ReduceIterableAllWindowFunction(ReduceFunction<T>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction
 
ReduceIterableWindowFunction<K,W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
 
ReduceIterableWindowFunction(ReduceFunction<T>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceIterableWindowFunction
 
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).
ReduceProperties - Class in org.apache.flink.optimizer.operators
 
ReduceProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.operators.ReduceProperties
 
ReduceProperties(FieldSet, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.ReduceProperties
 
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.
ReducingWindowBuffer<T> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
An WindowBuffer that stores elements on the Java Heap.
ReducingWindowBuffer(ReduceFunction<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
 
ReducingWindowBuffer(ReduceFunction<T>, StreamRecord<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
 
ReducingWindowBuffer.Factory<T> - Class in org.apache.flink.streaming.runtime.operators.windowing.buffers
 
reference - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
refId() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.RecursiveDescriptor
 
ReflectionUtil - Class in org.apache.flink.util
 
RefuseRegistration(String) - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.RefuseRegistration
 
RefuseRegistration$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.RefuseRegistration$
 
register(Logger) - Static method in class org.apache.flink.runtime.util.SignalHandler
Register some signal handlers.
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.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<?>) - 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.
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$
 
RegisterApplicationMasterResponseReflector - Class in org.apache.flink.yarn
Singleton object to reflect the getContainersFromPreviousAttempts method for RegisterApplicationMasterResponse.
RegisterApplicationMasterResponseReflector() - Constructor for class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector
 
RegisterApplicationMasterResponseReflector$ - Class in org.apache.flink.yarn
Singleton object to reflect the getContainersFromPreviousAttempts method for RegisterApplicationMasterResponse.
RegisterApplicationMasterResponseReflector$() - Constructor for class org.apache.flink.yarn.RegisterApplicationMasterResponseReflector$
 
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.
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.
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(EventListener<CheckpointBarrier>) - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
 
registerCheckpointEventHandler(EventListener<CheckpointBarrier>) - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
 
registerCheckpointEventHandler(EventListener<CheckpointBarrier>) - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Registers the given event handler to be notified on successful checkpoints.
registerConsumer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
RegisteredAtJobManager$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.RegisteredAtJobManager$
 
registeredPartitions - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
RegisteredTaskManagers(Iterable<Instance>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers
 
RegisteredTaskManagers$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers$
 
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.NonKeyedWindowOperator.Context
 
registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
registerExecutionListener(ActorGateway) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
registerExecutionListener(ActorGateway) - Method in class org.apache.flink.runtime.taskmanager.Task
 
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
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.
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.
registerJobStatusListener(ActorGateway) - 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.
registerListener(EventListener<InputGate>) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
registerListener(EventListener<InputGate>) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
registerListener(EventListener<InputGate>) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
registerListener(NotificationListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
Subscribes to data availability notifications.
registerLocalResource(FileSystem, Path, LocalResource) - Static method in class org.apache.flink.yarn.Utils
 
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.
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.NonKeyedWindowOperator.Context
 
registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
registerResultPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
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
 
registerTaskManager(ActorRef, InstanceConnectionInfo, HardwareDescription, int, UUID) - Method in class org.apache.flink.runtime.instance.InstanceManager
Registers a task manager.
RegisterTaskManager(InstanceConnectionInfo, HardwareDescription, int) - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager
 
RegisterTaskManager$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager$
 
registerTimer(long, Triggerable) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Register a timer callback.
registerTimer(long, Triggerable) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Register a timer callback.
registerTimer(long, Triggerable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Registers a timer.
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
 
RegistrationMessages - Class in org.apache.flink.runtime.messages
A set of messages from the between TaskManager and JobManager 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 from the between TaskManager and JobManager 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 job manager.
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 job manager.
RegistrationMessages.RefuseRegistration$ - Class in org.apache.flink.runtime.messages
 
RegistrationMessages.RegisterTaskManager - Class in org.apache.flink.runtime.messages
Registers a task manager at the job manager.
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
 
Regularization$() - Constructor for class org.apache.flink.ml.classification.SVM.Regularization$
 
RegularizationConstant$() - Constructor for class org.apache.flink.ml.optimization.Solver.RegularizationConstant$
 
RegularToMutableObjectIterator<T> - Class in org.apache.flink.runtime.util
 
RegularToMutableObjectIterator(Iterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
release(K, V, long) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Decreases the reference counter for the given value, key, timstamp 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.
releaseAll(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
Releases all memory segments for the given owner.
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 class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
 
releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
releaseArrays() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
releaseBroadcastVariables(String, int, DistributedRuntimeUDFContext) - Method in class org.apache.flink.runtime.operators.BatchTask
 
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
 
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
 
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.
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
 
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) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, Tuple2<Integer, Integer>) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
RemoteInputChannel.BufferReorderingException - Exception in org.apache.flink.runtime.io.network.partition.consumer
 
RemoteStreamEnvironment - Class in org.apache.flink.streaming.api.environment
 
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() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
remove() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
remove(K, V, long) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Removes the given value, key, timestamp entry if its reference counter is 0.
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() - Method in class org.apache.flink.runtime.jobgraph.tasks.InputSplitIterator
 
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.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() - Method in class org.apache.flink.runtime.util.UnionIterator
 
remove(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Removes a state handle from ZooKeeper.
remove(String, BackgroundCallback) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Removes a state handle from ZooKeeper asynchronously.
remove(Object) - Method in class org.apache.flink.storm.util.StormConfig
 
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.NumberSequenceIterator
 
removeAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
removeAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
 
removeAndDiscardAllState() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Discards all available state handles and removes them from ZooKeeper.
removeAndDiscardState(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Discards a state handle and removes it from ZooKeeper.
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.
removeElements(int) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.EvictingWindowBuffer
Removes the given number of elements, starting from the beginning.
removeElements(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
 
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$() - 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
 
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
 
RemoveRangeIndex<T> - Class in org.apache.flink.runtime.operators.udf
 
RemoveRangeIndex() - Constructor for class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
 
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.
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.
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.runtime.fs.hdfs.HadoopFileSystem
 
rename(Path, Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
RenameOperator<T> - Class in org.apache.flink.api.table.typeinfo
This is a logical operator that can hold a RenamingProxyTypeInfo for renaming some fields of a CompositeType.
RenameOperator(DataSet<T>, RenamingProxyTypeInfo<T>) - Constructor for class org.apache.flink.api.table.typeinfo.RenameOperator
 
RenamingProxyTypeInfo<T> - Class in org.apache.flink.api.table.typeinfo
A TypeInformation that is used to rename fields of an underlying CompositeType.
RenamingProxyTypeInfo(CompositeType<T>, String[]) - Constructor for class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
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
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.
replaceNonWordChars(StringValue, char) - Static method in class org.apache.flink.util.SimpleStringUtils
Replaces all non-word characters in a string by a given character.
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
 
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, byte[]) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
reportNumBytesIn(long) - Method in interface org.apache.flink.runtime.accumulators.AccumulatorRegistry.Reporter
 
reportNumBytesOut(long) - Method in interface org.apache.flink.runtime.accumulators.AccumulatorRegistry.Reporter
 
reportNumRecordsIn(long) - Method in interface org.apache.flink.runtime.accumulators.AccumulatorRegistry.Reporter
 
reportNumRecordsOut(long) - Method in interface org.apache.flink.runtime.accumulators.AccumulatorRegistry.Reporter
 
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$
 
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.
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.
requestIFEQLoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
requestIFNELoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
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
 
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$
 
RequestNumberRegisteredTaskManager$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestNumberRegisteredTaskManager$
 
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(JobID, ResultPartitionID, ExecutionAttemptID, IntermediateDataSetID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionState
 
RequestPartitionState$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionState$
 
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$
 
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(InstanceID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestStackTrace
 
RequestStackTrace$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestStackTrace$
 
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.
requestSubpartition(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
 
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$
 
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$
 
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.
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
 
requiresComparator() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
 
requiresComparator() - Method in enum org.apache.flink.runtime.operators.util.LocalStrategy
 
RequiresLeaderSessionID - Interface in org.apache.flink.runtime.messages
Marks messages to be sent wrapped in a JobManagerMessages.LeaderSessionMessage
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.graph.library.Summarization.VertexGroupItem
Resets the fields to initial values.
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.streaming.data.PythonSender
Resets this object to the post-configuration state.
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 interface org.apache.flink.runtime.util.ResettableIterator
Resets the iterator.
reset() - Method in interface org.apache.flink.runtime.util.ResettableMutableObjectIterator
Resets the iterator.
resetAllInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
 
resetAndClearAccumulators(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
 
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
 
resetEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
 
resetForNewExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
resetForNewExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
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.Histogram
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
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.SerializedListAccumulator
 
resetLocal() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
resetLocal() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsAccumulator
 
resetLocal() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
resetLocal() - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.DefaultKafkaMetricAccumulator
 
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
 
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
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
 
resolveClass(ObjectStreamClass) - Method in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
ResolvedFieldReference - Class in org.apache.flink.api.table.expressions
 
ResolvedFieldReference(String, TypeInformation<?>) - Constructor for class org.apache.flink.api.table.expressions.ResolvedFieldReference
 
ResolvedFieldReference$ - Class in org.apache.flink.api.table.expressions
 
ResolvedFieldReference$() - Constructor for class org.apache.flink.api.table.expressions.ResolvedFieldReference$
 
ResolveFieldReferences - Class in org.apache.flink.api.table.expressions.analysis
Rule that resolved field references.
ResolveFieldReferences(Seq<Tuple2<String, TypeInformation<?>>>) - Constructor for class org.apache.flink.api.table.expressions.analysis.ResolveFieldReferences
 
ResourceId - Class in org.apache.flink.runtime.jobmanager.scheduler
 
ResourceId() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ResourceId
 
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
ResponseArchive(ActorRef) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseArchive
 
ResponseArchive$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseArchive$
 
ResponseLeaderSessionID(UUID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseLeaderSessionID
 
ResponseLeaderSessionID$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseLeaderSessionID$
 
ResponseStackTraceSampleFailure(int, ExecutionAttemptID, Exception) - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleFailure
 
ResponseStackTraceSampleFailure$() - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleFailure$
 
ResponseStackTraceSampleSuccess(int, ExecutionAttemptID, List<StackTraceElement[]>) - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleSuccess
 
ResponseStackTraceSampleSuccess$() - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleSuccess$
 
ResponseWebMonitorPort(Integer) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseWebMonitorPort
 
ResponseWebMonitorPort$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseWebMonitorPort$
 
restart() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
restart(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
restart(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
restart(ExecutionGraph) - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
Restarts the given ExecutionGraph.
RESTART_STRATEGY - Static variable in class org.apache.flink.configuration.ConfigConstants
Defines the restart strategy to be used.
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.
restartLeadingJobManager() - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
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.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
 
restartTaskManager(int) - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
restoreFromSnapshot(DataInputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer.Factory
 
restoreFromSnapshot(DataInputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer.Factory
 
restoreFromSnapshot(DataInputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer.Factory
 
restoreFromSnapshot(DataInputView) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBufferFactory
Restores a WindowBuffer from a previous snapshot written using WindowBuffer.snapshot(DataOutputView).
restoreLatestCheckpointedState(Map<JobVertexID, ExecutionJobVertex>, boolean, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
restoreLatestCheckpointedState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Restores the latest checkpointed state.
restoreSavepoint(Map<JobVertexID, ExecutionJobVertex>, String) - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
Resets the state of Execution instances back to the state of a savepoint.
restoreSavepoint(String) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Restores the execution state back to a savepoint.
restoreState(StreamTaskState, long) - Method in class org.apache.flink.cep.operator.CEPPatternOperator
 
restoreState(StreamTaskState, long) - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
restoreState(RocksDBStateBackend, TypeSerializer<K>, ClassLoader, long) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
 
restoreState(Backend, TypeSerializer<K>, ClassLoader, long) - Method in class org.apache.flink.runtime.state.AsynchronousKvStateSnapshot
 
restoreState(FsStateBackend, TypeSerializer<K>, ClassLoader, long) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
 
restoreState(Backend, TypeSerializer<K>, ClassLoader, long) - Method in interface org.apache.flink.runtime.state.KvStateSnapshot
Loads the key/value state back from this snapshot.
restoreState(MemoryStateBackend, TypeSerializer<K>, ClassLoader, long) - Method in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
 
restoreState(T) - Method in interface org.apache.flink.streaming.api.checkpoint.Checkpointed
Restores the state of the function or operator to that of a previous checkpoint.
restoreState(Integer) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
restoreState(SerializedCheckpointData[]) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
restoreState(Long) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
restoreState(StreamTaskState, long) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
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.RollingSink
 
restoreState(HashMap<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
 
restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
restoreState(StreamTaskState, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
restoreToOffset - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
The offsets to restore to, if the consumer restores state from a checkpoint
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
 
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, JobID, ResultPartitionID, ResultPartitionType, boolean, int, ResultPartitionManager, ResultPartitionConsumableNotifier, IOManager, IOManager.IOMode) - 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, 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
 
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
 
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
 
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.api.table.codegen.ExpressionCodeGenerator.GeneratedExpression
 
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.
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.
retriggerPartitionRequest(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Retriggers a partition request.
retry(Callable<X>, int) - Static method in class org.apache.flink.contrib.streaming.state.SQLRetrier
Tries to run the given Callable the predefined number of times before throwing an IOException.
retry(Callable<X>, int, int) - Static method in class org.apache.flink.contrib.streaming.state.SQLRetrier
Tries to run the given Callable the predefined number of times before throwing an IOException.
retry(Callable<X>, Callable<Y>, int, int) - Static method in class org.apache.flink.contrib.streaming.state.SQLRetrier
Tries to run the given Callable the predefined number of times before throwing an IOException.
retry(Callable<X>, Callable<Y>, int) - Static method in class org.apache.flink.contrib.streaming.state.SQLRetrier
Tries to run the given Callable the predefined number of times before throwing an IOException.
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(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.
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.
returnAllocatedSlot(Slot) - Method in class org.apache.flink.runtime.instance.Instance
Returns a slot that has been allocated from this instance.
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
 
reusableInitStatements() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
reusableMemberStatements() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
reuse - Variable in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
reuseCode(CompositeType<A>) - Method in class org.apache.flink.api.table.codegen.GenerateResultAssembler
 
reuseInitCode() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
reuseMemberCode() - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
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 interface org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by the LeaderElectionService upon revoking the leadership of a former leader.
RevokeLeadership$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RevokeLeadership$
 
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
 
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
 
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
Rich variant of the FoldFunction.
RichFoldFunction() - Constructor for class org.apache.flink.api.common.functions.RichFoldFunction
 
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
 
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
 
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.api.table.expressions.And
 
right() - Method in class org.apache.flink.api.table.expressions.BinaryExpression
 
right() - Method in class org.apache.flink.api.table.expressions.BitwiseAnd
 
right() - Method in class org.apache.flink.api.table.expressions.BitwiseOr
 
right() - Method in class org.apache.flink.api.table.expressions.BitwiseXor
 
right() - Method in class org.apache.flink.api.table.expressions.Div
 
right() - Method in class org.apache.flink.api.table.expressions.EqualTo
 
right() - Method in class org.apache.flink.api.table.expressions.GreaterThan
 
right() - Method in class org.apache.flink.api.table.expressions.GreaterThanOrEqual
 
right() - Method in class org.apache.flink.api.table.expressions.LessThan
 
right() - Method in class org.apache.flink.api.table.expressions.LessThanOrEqual
 
right() - Method in class org.apache.flink.api.table.expressions.Minus
 
right() - Method in class org.apache.flink.api.table.expressions.Mod
 
right() - Method in class org.apache.flink.api.table.expressions.Mul
 
right() - Method in class org.apache.flink.api.table.expressions.NotEqualTo
 
right() - Method in class org.apache.flink.api.table.expressions.Or
 
right() - Method in class org.apache.flink.api.table.expressions.Plus
 
right() - Method in class org.apache.flink.api.table.plan.Join
 
right() - Method in class org.apache.flink.api.table.plan.UnionAll
 
right() - Method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
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>) - 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.
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
 
rightTypeInfo() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
rmClientOption() - Method in class org.apache.flink.yarn.YarnJobManager
 
RMQSink<IN> - Class in org.apache.flink.streaming.connectors.rabbitmq
 
RMQSink(String, 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(String, 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(String, String, boolean, DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
Creates a new RabbitMQ source.
RMQSource(String, Integer, String, boolean, DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
Creates a new RabbitMQ source.
RMQSource(String, Integer, String, String, 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
 
RocksDBFoldingState<K,N,T,ACC> - Class in org.apache.flink.contrib.streaming.state
FoldingState implementation that stores state in RocksDB.
RocksDBFoldingState(TypeSerializer<K>, TypeSerializer<N>, FoldingStateDescriptor<T, ACC>, File, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
Creates a new RocksDBFoldingState.
RocksDBFoldingState(TypeSerializer<K>, TypeSerializer<N>, FoldingStateDescriptor<T, ACC>, File, String, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
Creates a RocksDBFoldingState by restoring from a directory.
RocksDBListState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
ListState implementation that stores state in RocksDB.
RocksDBListState(TypeSerializer<K>, TypeSerializer<N>, ListStateDescriptor<V>, File, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBListState
Creates a new RocksDBListState.
RocksDBListState(TypeSerializer<K>, TypeSerializer<N>, ListStateDescriptor<V>, File, String, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBListState
Creates a RocksDBListState by restoring from a directory.
rocksDbPath - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Directory in "basePath" where the actual RocksDB data base instance stores its files
RocksDBReducingState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
ReducingState implementation that stores state in RocksDB.
RocksDBReducingState(TypeSerializer<K>, TypeSerializer<N>, ReducingStateDescriptor<V>, File, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBReducingState
Creates a new RocksDBReducingState.
RocksDBReducingState(TypeSerializer<K>, TypeSerializer<N>, ReducingStateDescriptor<V>, File, String, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBReducingState
Creates a RocksDBReducingState by restoring from a directory.
RocksDBStateBackend - Class in org.apache.flink.contrib.streaming.state
A StateBackend 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(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(String, AbstractStateBackend) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
RocksDBStateBackend(URI, AbstractStateBackend) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
RocksDBValueState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
ValueState implementation that stores state in RocksDB.
RocksDBValueState(TypeSerializer<K>, TypeSerializer<N>, ValueStateDescriptor<V>, File, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBValueState
Creates a new RocksDBValueState.
RocksDBValueState(TypeSerializer<K>, TypeSerializer<N>, ValueStateDescriptor<V>, File, String, String, Options) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBValueState
Creates a RocksDBValueState by restoring from a directory.
RollingSink<T> - Class in org.apache.flink.streaming.connectors.fs
Sink that emits its input elements to rolling FileSystem files.
RollingSink(String) - Constructor for class org.apache.flink.streaming.connectors.fs.RollingSink
Creates a new RollingSink that writes files to the given base directory.
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.
Root<T> - Class in org.apache.flink.api.table.plan
Operation that transforms a DataSet or DataStream into a Table.
Root(T, Seq<Tuple2<String, TypeInformation<?>>>) - Constructor for class org.apache.flink.api.table.plan.Root
 
Root$ - Class in org.apache.flink.api.table.plan
 
Root$() - Constructor for class org.apache.flink.api.table.plan.Root$
 
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.runtime.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.
Row - Class in org.apache.flink.api.table
This is used for executing Table API operations.
Row(int) - Constructor for class org.apache.flink.api.table.Row
 
RowComparator - Class in org.apache.flink.api.table.typeinfo
Comparator for Row.
RowComparator(int[], NullAwareComparator<Object>[], TypeSerializer<Object>[]) - Constructor for class org.apache.flink.api.table.typeinfo.RowComparator
Intermediate constructor for creating auxiliary fields.
RowComparator(int[], TypeComparator<Object>[], TypeSerializer<Object>[], boolean[]) - Constructor for class org.apache.flink.api.table.typeinfo.RowComparator
General constructor for RowComparator.
RowComparator$ - Class in org.apache.flink.api.table.typeinfo
 
RowComparator$() - Constructor for class org.apache.flink.api.table.typeinfo.RowComparator$
 
rowIndices() - Method in class org.apache.flink.ml.math.SparseMatrix
 
RowSerializer - Class in org.apache.flink.api.table.typeinfo
Serializer for Row.
RowSerializer(TypeSerializer<Object>[]) - Constructor for class org.apache.flink.api.table.typeinfo.RowSerializer
 
RowTypeInfo - Class in org.apache.flink.api.table.typeinfo
TypeInformation for Row.
RowTypeInfo(Seq<TypeInformation<?>>, Seq<String>) - Constructor for class org.apache.flink.api.table.typeinfo.RowTypeInfo
 
RowTypeInfo(Seq<Expression>) - Constructor for class org.apache.flink.api.table.typeinfo.RowTypeInfo
 
Rule<A extends TreeNode<A>> - Class in org.apache.flink.api.table.trees
Base class for a rule that is part of an Analyzer rule chain.
Rule() - Constructor for class org.apache.flink.api.table.trees.Rule
 
rules() - Method in class org.apache.flink.api.table.expressions.analysis.GroupByAnalyzer
 
rules() - Method in class org.apache.flink.api.table.expressions.analysis.PredicateAnalyzer
 
rules() - Method in class org.apache.flink.api.table.expressions.analysis.SelectionAnalyzer
 
rules() - Method in class org.apache.flink.api.table.trees.Analyzer
 
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(String[]) - Method in class org.apache.flink.client.FlinkYarnSessionCli
 
run(GraphAlgorithm<K, VV, EV, T>) - Method in class org.apache.flink.graph.Graph
 
run(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.GraphAlgorithm
 
run(Graph<K, Long, Double>) - Method in class org.apache.flink.graph.library.CommunityDetection
 
run(Graph<K, Long, EV>) - Method in class org.apache.flink.graph.library.ConnectedComponents
 
run(Graph<K, Long, EV>) - Method in class org.apache.flink.graph.library.GSAConnectedComponents
 
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.library.GSAPageRank
 
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.library.GSASingleSourceShortestPaths
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.GSATriangleCount
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.LabelPropagation
 
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.library.PageRank
 
run(Graph<K, Double, 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() - 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.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 interface org.apache.flink.runtime.security.SecurityUtils.FlinkSecuredRunner
 
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(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
 
run(SourceFunction.SourceContext<Tuple3<String, Long, Long>>) - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
 
run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.FileSourceFunction
 
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<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(Object, 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.FlinkKafkaConsumer08
 
run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
run(SourceFunction.SourceContext<T>, KeyedDeserializationSchema<T>, HashMap<KafkaTopicPartition, Long>) - Method in interface org.apache.flink.streaming.connectors.kafka.internals.Fetcher
Starts fetch data from Kafka and emitting it into the stream.
run(SourceFunction.SourceContext<T>, KeyedDeserializationSchema<T>, HashMap<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher
 
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<Tuple3<Long, String, Integer>>) - Method in class org.apache.flink.streaming.examples.join.WindowJoin.GradeSource
 
run(SourceFunction.SourceContext<Tuple3<Long, String, Integer>>) - Method in class org.apache.flink.streaming.examples.join.WindowJoin.SalarySource
 
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.StreamIterationHead
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
run(String[]) - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
run() - Method in class org.apache.flink.yarn.FlinkYarnCluster.ClientShutdownHook
 
run() - Method in class org.apache.flink.yarn.FlinkYarnCluster.PollingThread
 
runAction() - Method in class org.apache.flink.yarn.ApplicationMasterBase
 
runBlocking(PackagedProgram, int) - Method in class org.apache.flink.client.program.Client
 
runBlocking(JobWithJars, int) - Method in class org.apache.flink.client.program.Client
 
runBlocking(JobWithJars, int, String) - Method in class org.apache.flink.client.program.Client
Runs a program on the Flink cluster to which this client is connected.
runBlocking(FlinkPlan, List<URL>, List<URL>, ClassLoader) - Method in class org.apache.flink.client.program.Client
 
runBlocking(FlinkPlan, List<URL>, List<URL>, ClassLoader, String) - Method in class org.apache.flink.client.program.Client
 
runBlocking(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.Client
 
runDetached(PackagedProgram, int) - Method in class org.apache.flink.client.program.Client
 
runDetached(JobWithJars, int) - Method in class org.apache.flink.client.program.Client
 
runDetached(JobWithJars, int, String) - Method in class org.apache.flink.client.program.Client
Submits a program to the Flink cluster to which this client is connected.
runDetached(FlinkPlan, List<URL>, List<URL>, ClassLoader) - Method in class org.apache.flink.client.program.Client
 
runDetached(FlinkPlan, List<URL>, List<URL>, ClassLoader, String) - Method in class org.apache.flink.client.program.Client
 
runDetached(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.Client
 
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.
runInteractiveCli(AbstractFlinkYarnCluster) - Static method in class org.apache.flink.client.FlinkYarnSessionCli
 
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.
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 - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Flag indicating whether the consumer is still running
running() - Method in class org.apache.flink.yarn.ApplicationClient
 
runningContainers() - Method in class org.apache.flink.yarn.YarnJobManager
 
runningContainersList() - Method in class org.apache.flink.yarn.YarnJobManager
 
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$
 
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() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Registry of all tasks currently executed by this TaskManager
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
 
runScatterGatherIteration(VertexUpdateFunction<K, VV, M>, MessagingFunction<K, VV, M, EV>, int) - Method in class org.apache.flink.graph.Graph
Runs a ScatterGather iteration on the graph.
runScatterGatherIteration(VertexUpdateFunction<K, VV, M>, MessagingFunction<K, VV, M, EV>, int, ScatterGatherConfiguration) - Method in class org.apache.flink.graph.Graph
Runs a ScatterGather iteration on the graph with configuration options.
runScatterGatherIteration(VertexUpdateFunction<K, VV, M>, MessagingFunction<K, VV, M, EV>, int) - Method in class org.apache.flink.graph.scala.Graph
Runs a scatter-gather iteration on the graph.
runScatterGatherIteration(VertexUpdateFunction<K, VV, M>, MessagingFunction<K, VV, M, EV>, int, ScatterGatherConfiguration) - Method in class org.apache.flink.graph.scala.Graph
Runs a scatter-gather iteration on the graph with configuration options.
runSecured(SecurityUtils.FlinkSecuredRunner<T>) - Static method in class org.apache.flink.runtime.security.SecurityUtils
 
runTaskManager(String, int, Configuration) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Starts and runs the TaskManager.
runTaskManager(String, int, Configuration, Class<? extends TaskManager>) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Starts and runs the TaskManager.
runTaskManager(String, int, Configuration) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Starts and runs the TaskManager.
runTaskManager(String, int, Configuration, 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, TaskInfo, Configuration, Configuration, ClassLoader, MemoryManager, IOManager, BroadcastVariableManager, AccumulatorRegistry, InputSplitProvider, Map<String, Future<Path>>, ResultPartitionWriter[], InputGate[], ActorGateway, TaskManagerRuntimeInfo) - 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(RequestHandler, JobManagerRetriever, Future<String>, FiniteDuration) - Constructor for class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
 
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<?, ?>>) - 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.
runYarnTaskManager(String[], Class<T>) - Static method in class org.apache.flink.yarn.YarnTaskManagerRunner
 

S

SALARIES_INPUT - Static variable in class org.apache.flink.streaming.examples.join.util.WindowJoinData
 
salary() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Person
 
Salary(long, 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$
 
salaryMax() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
salaryMax() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
SalarySource() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoin.SalarySource
 
salaryStream() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
salaryStream() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
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.ResponseStackTraceSampleFailure
 
sampleId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleSuccess
 
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
 
samples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.ResponseStackTraceSampleSuccess
 
SampleTaskStackTrace(int, ExecutionAttemptID, FiniteDuration, 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.
savepoint(String[]) - Method in class org.apache.flink.client.CliFrontend
Executes the SAVEPOINT action.
SAVEPOINT_BACKEND_KEY - Static variable in class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
 
SAVEPOINT_DIRECTORY_KEY - Static variable in class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
 
SavepointCoordinator - Class in org.apache.flink.runtime.checkpoint
The savepoint coordinator is a slightly modified variant of the regular checkpoint coordinator.
SavepointCoordinator(JobID, long, long, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], ClassLoader, CheckpointIDCounter, StateStore<CompletedCheckpoint>, CheckpointStatsTracker) - Constructor for class org.apache.flink.runtime.checkpoint.SavepointCoordinator
 
SavepointCoordinatorDeActivator - Class in org.apache.flink.runtime.checkpoint
This actor listens to changes in the JobStatus and deactivates the savepoint scheduler and discards all pending checkpoints.
SavepointCoordinatorDeActivator(SavepointCoordinator, UUID) - Constructor for class org.apache.flink.runtime.checkpoint.SavepointCoordinatorDeActivator
 
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 - Variable in class org.apache.flink.client.program.ContextEnvironment
 
savepointPath() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepoint
 
savepointPath() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointSuccess
 
SavepointStore - Class in org.apache.flink.runtime.checkpoint
Simple wrapper around the state store for savepoints.
SavepointStore(StateStore<CompletedCheckpoint>) - Constructor for class org.apache.flink.runtime.checkpoint.SavepointStore
 
savepointStore() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
SavepointStoreFactory - Class in org.apache.flink.runtime.checkpoint
Factory for savepoint StateStore instances.
SavepointStoreFactory() - Constructor for class org.apache.flink.runtime.checkpoint.SavepointStoreFactory
 
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
 
ScalaBatchTranslator - Class in org.apache.flink.api.scala.table
PlanTranslator for creating Tables from Scala DataSets and translating them back to Scala DataSets.
ScalaBatchTranslator() - Constructor for class org.apache.flink.api.scala.table.ScalaBatchTranslator
 
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.
scalaEnv() - Method in class org.apache.flink.api.scala.FlinkILoop
 
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
 
ScalaNothingTypeInfo - Class in org.apache.flink.api.scala.typeutils
 
ScalaNothingTypeInfo() - Constructor for class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
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
 
ScalaShellRemoteEnvironment - Class in org.apache.flink.api.java
Special version of RemoteEnvironment that has a reference to a FlinkILoop.
ScalaShellRemoteEnvironment(String, int, FlinkILoop, String...) - Constructor for class org.apache.flink.api.java.ScalaShellRemoteEnvironment
Creates new ScalaShellRemoteEnvironment that has a reference to the FlinkILoop
ScalaStreamingTranslator - Class in org.apache.flink.api.scala.table
PlanTranslator for creating Tables from Scala DataStreams and translating them back to Scala DataStreams.
ScalaStreamingTranslator() - Constructor for class org.apache.flink.api.scala.table.ScalaStreamingTranslator
 
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.TableInputFormat
 
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 VertexUpdateFunction and MessagingFunction The VertexCentricConfiguration object is passed as an argument to ( org.apache.flink.graph.spargel.VertexUpdateFunction, org.apache.flink.graph.spargel.MessagingFunction, 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.
scheduleAll(Scheduler, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
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(Scheduler, 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(Scheduler) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
scheduleForExecution(Scheduler, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
scheduleImmediately(ScheduledUnit) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
ScheduleMode - Enum in org.apache.flink.runtime.jobgraph
 
scheduleOrUpdateConsumers(ResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
ScheduleOrUpdateConsumers(JobID, ResultPartitionID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ScheduleOrUpdateConsumers
 
ScheduleOrUpdateConsumers$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ScheduleOrUpdateConsumers$
 
scheduleQueued(ScheduledUnit) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
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(ExecutionContext) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Creates a new scheduler.
schema - Variable in class org.apache.flink.streaming.api.functions.source.ConnectorSource
 
schema - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
(Serializable) SerializationSchema for turning objects used with Flink into byte[] for Kafka.
schema - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
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.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of seconds.
SecurityUtils - Class in org.apache.flink.runtime.security
A utility class that lets program code run in a security context provided by the Hadoop security user groups.
SecurityUtils.FlinkSecuredRunner<T> - Interface in org.apache.flink.runtime.security
 
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.FSDataInputStream
Seek to the given offset from the start of the file.
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.
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 - Class in org.apache.flink.api.table.plan
Selection expression.
Select(PlanNode, Seq<Expression>) - Constructor for class org.apache.flink.api.table.plan.Select
 
select(Seq<Expression>) - Method in class org.apache.flink.api.table.Table
Performs a selection operation.
select(String) - Method in class org.apache.flink.api.table.Table
Performs a selection operation.
select(Map<String, 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(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$ - Class in org.apache.flink.api.table.plan
 
Select$() - Constructor for class org.apache.flink.api.table.plan.Select$
 
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
 
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.
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.
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.HashPartitioner
 
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
 
SelectDataFlatMap() - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterStreaming.SelectDataFlatMap
 
SelectEnglishAndTokenizeFlatMap() - Constructor for class org.apache.flink.streaming.examples.twitter.TwitterStream.SelectEnglishAndTokenizeFlatMap
 
selection() - Method in class org.apache.flink.api.table.plan.Select
 
SelectionAnalyzer - Class in org.apache.flink.api.table.expressions.analysis
This analyzes selection expressions.
SelectionAnalyzer(Seq<Tuple2<String, TypeInformation<?>>>) - Constructor for class org.apache.flink.api.table.expressions.analysis.SelectionAnalyzer
 
SelectLanguageFlatMap() - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterTopology.SelectLanguageFlatMap
 
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) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
selectNetworkInterfaceAndPort(Configuration) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
selectNetworkInterfaceAndRunTaskManager(Configuration, Class<? extends TaskManager>) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Starts and runs the TaskManager.
selectNetworkInterfaceAndRunTaskManager(Configuration, 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
 
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.
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.
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(Iterator, int) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
Extracts records from an iterator and writes them to the memory-mapped file.
sendEndOfSuperstep() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
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() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
sendError(Exception) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarActionHandler
 
SendHeartbeat$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.SendHeartbeat$
 
sendHeartbeatToJobManager() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Sends a heartbeat message to the JobManager (if connected) with the current metrics report.
sendMessages(Vertex<Long, Double>) - Method in class org.apache.flink.graph.examples.IncrementalSSSP.InvalidateMessenger
 
sendMessages(Vertex<Long, Double>) - Method in class org.apache.flink.graph.examples.SingleSourceShortestPaths.MinDistanceMessenger
 
sendMessages(Vertex<K, Tuple2<Long, Double>>) - Method in class org.apache.flink.graph.library.CommunityDetection.LabelMessenger
 
sendMessages(Vertex<K, Long>) - 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.PageRank.RankMessenger
 
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.MessagingFunction
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.spargel.MessagingFunction
Sends the given message to the vertex identified by the given key.
sendMessageToAllNeighbors(Message) - Method in class org.apache.flink.graph.spargel.MessagingFunction
Sends the given message to all vertices that are targets of an edge of the changed vertex.
sendMessageToCurrentExecution(Serializable, ExecutionAttemptID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
sendMessageToCurrentExecution(Serializable, ExecutionAttemptID, ActorGateway) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
SendNewLabelToNeighbors(TypeInformation<VV>) - Constructor for class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
 
sendOutputs(OUT) - Method in interface org.apache.flink.streaming.api.collector.selector.OutputSelectorWrapper
 
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.data.PythonSender
Writes a single record to the memory-mapped file.
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
 
SendStackTrace$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.SendStackTrace$
 
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
 
sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
 
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.
SerializableArrayList<E extends IOReadableWritable> - Class in org.apache.flink.runtime.util
This class extends a standard ArrayList by implementing the IOReadableWritable interface.
SerializableArrayList() - Constructor for class org.apache.flink.runtime.util.SerializableArrayList
Constructs an empty list with an initial capacity of ten.
SerializableArrayList(int) - Constructor for class org.apache.flink.runtime.util.SerializableArrayList
Constructs an empty list with the specified initial capacity.
SerializableHashMap<K extends IOReadableWritable,V extends IOReadableWritable> - Class in org.apache.flink.runtime.util
This class extends a standard HashMap by implementing the IOReadableWritable interface.
SerializableHashMap() - Constructor for class org.apache.flink.runtime.util.SerializableHashMap
 
SerializableHashSet<T extends IOReadableWritable> - Class in org.apache.flink.runtime.util
This class extends a standard HashSet by implementing the IOReadableWritable interface.
SerializableHashSet() - Constructor for class org.apache.flink.runtime.util.SerializableHashSet
 
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<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(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(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(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(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.TypeSerializer
Serializes the given record to the given target output view.
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(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(Row, DataOutputView) - Method in class org.apache.flink.api.table.typeinfo.RowSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
Serializes the given record.
serialize(IN) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
serialize(ArrayList<T>, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
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.MultiplexingStreamRecordSerializer
 
serialize(StreamRecord<T>, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
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(DataOutputView) - Method in class org.apache.flink.types.Record
Writes this record to the given output view.
SERIALIZED_WRAPPER_NAME - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.PartitionerWrapper
 
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
 
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
 
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.runtime.state.memory
A state handle that represents its state in serialized form as bytes.
SerializedStateHandle(T) - Constructor for class org.apache.flink.runtime.state.memory.SerializedStateHandle
Creates a new serialized state handle, eagerly serializing the given state object.
SerializedStateHandle(byte[]) - Constructor for class org.apache.flink.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.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
 
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
 
serializeObject(Object) - Static method in class org.apache.flink.util.InstantiationUtil
 
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
 
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() - Method in class org.apache.flink.api.table.typeinfo.RowComparator
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
 
serializeToByteArray(TypeSerializer<T>, T) - Static method in class org.apache.flink.util.InstantiationUtil
 
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
 
server - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
sessionAlive() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
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
 
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
 
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(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(E) - Method in class org.apache.flink.runtime.util.SingleElementIterator
Resets the element.
set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor.ArrayFieldAccessor
 
set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor.PojoFieldAccessor
 
set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor.ProductFieldAccessor
 
set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor
 
set(R, R) - Method in class org.apache.flink.streaming.util.FieldAccessor.SimpleFieldAccessor
 
set(R, F) - Method in class org.apache.flink.streaming.util.FieldAccessor.TupleFieldAccessor
 
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
 
setAccumulatedRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
Sets the accumulatedRecordCount to the specified value.
setAccumulators(Map<AccumulatorRegistry.Metric, Accumulator<?, ?>>, Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.executiongraph.Execution
Update accumulators (discarded when the Execution has already been terminated).
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.client.program.PreviewPlanEnvironment
 
setAsContext() - Method in class org.apache.flink.test.util.CollectionTestEnvironment
 
setAsContext() - Method in class org.apache.flink.test.util.TestEnvironment
 
setAsyncTimeout(long) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
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
 
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
 
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.RollingSink
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.recommendation.ALS
Sets the number of blocks into which the user and item matrix shall be partitioned
setBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setBoolean(String, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
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
 
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) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
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.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
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
 
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.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
 
setChannelIndex(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
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.
setCheckpointInsertParams(String, PreparedStatement, long, long, long, byte[]) - Method in interface org.apache.flink.contrib.streaming.state.DbAdapter
Set the PreparedStatement parameters for the statement returned by DbAdapter.prepareCheckpointInsert(String, Connection).
setCheckpointInsertParams(String, PreparedStatement, long, long, long, byte[]) - Method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
 
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
 
setCheckpointTimeout(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the maximum time that a checkpoint may take before being discarded.
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.runtime.operators.util.TaskConfig.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.
setClientConnectTimeoutSeconds(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
setClientNumThreads(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
setClock(Clock) - Static method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
This sets the internal Clock implementation.
setCodeAnalysisMode(CodeAnalysisMode) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the CodeAnalysisMode of the program.
setCollectCountDistinct(boolean) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setCollectHeavyHitters(boolean) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setCollectMax(boolean) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setCollectMin(boolean) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
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
 
setCommentPrefix(byte[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCommentPrefix(char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCommentPrefix(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCommentPrefix(String, String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCommentPrefix(String, Charset) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
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.runtime.yarn.AbstractFlinkYarnClient
 
setConfigurationDirectory(String) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
setConfigurationFilePath(Path) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
setConfigurationFilePath(Path) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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
 
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
 
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) - 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
 
setCountDbitmap(int) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setCountDistinctAlgorithm(OperatorStatisticsConfig.CountDistinctAlgorithm) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setCountDlog2m(int) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
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.contrib.streaming.state.AbstractRocksDBState
 
setCurrentKey(K) - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
 
setCurrentKey(K) - Method in class org.apache.flink.runtime.state.AbstractHeapState
 
setCurrentKey(Object) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
Sets the current key that is used for partitioned state.
setCurrentKey(K) - Method in class org.apache.flink.runtime.state.GenericFoldingState
 
setCurrentKey(K) - Method in class org.apache.flink.runtime.state.GenericListState
 
setCurrentKey(K) - Method in class org.apache.flink.runtime.state.GenericReducingState
 
setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.KvState
Sets the current key, which will be used when using the state access methods.
setCurrentNamespace(N) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
setCurrentNamespace(N) - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
 
setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.AbstractHeapState
 
setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.GenericFoldingState
 
setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.GenericListState
 
setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.GenericReducingState
 
setCurrentNamespace(N) - Method in interface org.apache.flink.runtime.state.KvState
Sets the current namespace, which will be used when using the state access methods.
setCurrentUserRetweet(CurrentUserRetweet) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
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.
setDbAdapter(DbAdapter) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Set the DbAdapter that will be used to operate on the database during checkpointing.
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) - 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.
setDegree(int) - Method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
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
 
setDeserializer(Properties) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
setDetachedMode(boolean) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
setDetachedMode(boolean) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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 MessagingFunction.
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
 
setDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setDouble(String, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.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
 
setDynamicPropertiesEncoded(String) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
setDynamicPropertiesEncoded(String) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
setEagerlyDeployConsumers(boolean) - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
Sets the flag indicating whether to eagerly deploy consumers (default: false).
setEdgeGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
setEdgeGroupValue(EV) - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
setEncodeForHTML(boolean) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
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.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.
setEstimatedNumRecords(long) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
setEstimatedOutputSize(long) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
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.
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
 
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, Object) - Method in class org.apache.flink.api.table.Row
 
setField(int, Value) - Method in class org.apache.flink.types.Record
Sets the field at the given position to the given value.
setFieldDelimiter(byte[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFieldDelimiter(char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
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
 
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
 
setFirst(U) - Method in class org.apache.flink.types.Pair
Sets the first encapsulated pair element to the specified value.
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.runtime.yarn.AbstractFlinkYarnClient
Flink configuration
setFlinkConfiguration(Configuration) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
setFlinkLoggingConfigurationPath(Path) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
setFlinkLoggingConfigurationPath(Path) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
setFloat(String, float) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setFloat(String, float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
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
 
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
 
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.streaming.runtime.tasks.StreamTaskState
 
setFurtherPatitioning(boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
setFutureAction(SlotAllocationFutureAction) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
 
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
 
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
 
setHeavyHitterAlgorithm(OperatorStatisticsConfig.HeavyHitterAlgorithm) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setHeavyHitterConfidence(double) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setHeavyHitterError(double) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setHeavyHitterFraction(double) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
setHeavyHitterSeed(int) - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig
 
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
 
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
 
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
 
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(SerializedValue<StateHandle<?>>, long) - Method in class org.apache.flink.runtime.executiongraph.Execution
 
setInitialState(T, long) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
Sets the initial state of the operator, upon recovery.
setInitialState(StreamTaskStateList, long) - 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.RollingSink
Sets the prefix of in-progress part files.
setInProgressSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
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<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.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
 
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.RollingSink
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
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(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.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
 
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) - 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
 
setJDBCDriver(String) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Set the class name that should be used to load the JDBC driver using Class.forName(JDBCDriverClass).
setJobId(JobID) - Method in class org.apache.flink.api.common.Plan
Sets the ID of the job that the dataflow plan belongs to.
setJobManagerMemory(int) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
setJobManagerMemory(int) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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
 
setJobStatusListener(ActorGateway) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
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
 
setKeyContext(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
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
 
setKvCacheSize(int) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Set the maximum number of key-value pairs stored in one task instance's cache before evicting to the underlying database.
setKvStateCompactionFrequency(int) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Sets how often will automatic compaction be performed on the database to remove old overwritten state changes.
setKvStates(HashMap<String, KvStateSnapshot<?, ?, ?, ?, ?>>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
 
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.
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
 
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.runtime.yarn.AbstractFlinkYarnClient
 
setLocalJarPath(Path) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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
 
setLocationConstraintHosts(List<Instance>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
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(String, long) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
setLossFunction(LossFunction) - Method in class org.apache.flink.ml.optimization.Solver
 
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
 
setMaxKvCacheEvictFraction(float) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Sets the maximum fraction of key-value states evicted from the cache if the cache is full.
setMaxKvInsertBatchSize(int) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Set the maximum number of key-value pairs inserted in the database as one batch operation.
setMaxNumberOfSqlRetries(int) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Sets the number of times each SQL command will be retried on failure.
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
 
setMetricsReport(byte[]) - Method in class org.apache.flink.runtime.instance.Instance
 
setMin(double) - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler
Sets the minimum for the range of the transformed data
setMinSplitSize(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
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.runtime.yarn.AbstractFlinkYarnClient
Set a name for the YARN application
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.FlinkYarnClientBase
 
setNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Sets the network cost for this Costs object.
setNewVertexValue(VV) - Method in class org.apache.flink.graph.spargel.VertexUpdateFunction
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
 
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.
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.api.table.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
Deprecated.
This method will be replaced by StreamExecutionEnvironment.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.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
 
setNumberOfSlots(int) - Method in class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
 
setNumberOfTaskManagers(int) - Method in class org.apache.flink.runtime.yarn.FlinkYarnClusterStatus
 
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.
setNumLineSamples(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setNumSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setNumTaskManagers(int) - Method in class org.apache.flink.test.util.AbstractTestBase
 
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
 
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
 
setOperatorPrettyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setOperatorState(StatefulTask<?>, StateHandle<?>, long) - Static method in class org.apache.flink.runtime.state.StateUtils
Utility method to define a common generic bound to be used for setting a generic state handle on a generic state carrier.
setOperatorState(StateHandle<?>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskState
 
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.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<ACC>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
 
setOutputType(TypeInformation<ACC>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
 
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
Is called by the org.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer, StreamOperator, TypeInformation, TypeInformation, String) method when the StreamGraph is generated.
setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
 
setOutputType(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Tries to fill in the type information.
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) - 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.IterationConfiguration
Sets the parallelism for the iteration.
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.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.
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(ShardedConnection.Partitioner) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Sets the partitioner used to assign keys to different database shards
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
setPartPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
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
 
setPendingPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Sets the prefix of pending part files.
setPendingSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Sets the suffix of pending part files.
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
 
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.Client
Configures whether the client should print progress updates during the execution to System.out.
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
 
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
 
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.runtime.yarn.AbstractFlinkYarnClient
 
setQueue(String) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
setQueuedSchedulingAllowed(boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setQueueSize(int) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
Set the size of the queue in which the tweets are contained temporarily.
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
 
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.
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(T1) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
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.PojoComparator
 
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(T) - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
setReference(Row) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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) - 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.
setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.reader.BufferReader
 
setReporter(AccumulatorRegistry.Reporter) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
Setter for the reporter, e.g.
setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
setReporter(AccumulatorRegistry.Reporter) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
Setter for the reporter, e.g.
setReporter(AccumulatorRegistry.Reporter) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Setter for the reporter, e.g.
setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
Counter for the number of records emitted and the records processed.
setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
setReporter(AccumulatorRegistry.Reporter) - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
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
 
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.
setRestartStrategyConfiguration(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
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
 
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.scala.function.util.ScalaAllWindowFunctionWrapper
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunctionWrapper
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
setSavepointPath(String) - Method in class org.apache.flink.client.program.PackagedProgram
 
setSavepointPath(String) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the savepoint path to rollback the deployment to.
setSavepointPath(String) - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
Sets the savepoint path.
setScheduleLocalOnly(boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
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
 
setSecond(V) - Method in class org.apache.flink.types.Pair
Sets the second encapsulated pair element to the specified value.
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).
setSendAndReceiveBufferSize(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
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
 
setServerConnectBacklog(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
setServerNumThreads(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
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.
setShipFiles(List<File>) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
List of files to transfer to the YARN containers.
setShipFiles(List<File>) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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
 
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
 
setSleepBetweenSqlRetries(int) - Method in class org.apache.flink.contrib.streaming.state.DbBackendConfig
Sets the number of milliseconds slept between two SQL retries.
setSlot(SimpleSlot) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
 
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(JobSnapshottingSettings) - 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.
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
 
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.
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
 
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) - 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(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig.DelegatingConfiguration
 
setStringToTokenize(StringValue) - Method in class org.apache.flink.util.SimpleStringUtils.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
 
setSymbols(List<Symbol>) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
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
 
setTaskManagerCount(int) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
setTaskManagerCount(int) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
setTaskManagerMemory(int) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnClient
 
setTaskManagerMemory(int) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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.runtime.yarn.AbstractFlinkYarnClient
 
setTaskManagerSlots(int) - Method in class org.apache.flink.yarn.FlinkYarnClientBase
 
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
 
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.api.table.TableConfig
Sets the timezone for date/time/timestamp conversions.
setTokensFor(ContainerLaunchContext, Path[], Configuration) - Static method in class org.apache.flink.yarn.Utils
 
setTransactionIsolation(int) - Method in class org.apache.flink.contrib.streaming.state.ShardedConnection
 
setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTransportType(String) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
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
 
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.
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.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 interface org.apache.flink.streaming.api.operators.StreamOperator
Initializes the operator.
setup() - Static method in class org.apache.flink.test.util.MultipleProgramsTestBase
 
setupConnectionFactory() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
Initializes the connection to RMQ with a default connection factory.
setupEnv(Configuration, Map<String, String>) - Static method in class org.apache.flink.yarn.Utils
 
setupLocalResource(Configuration, FileSystem, String, Path, LocalResource, Path) - Static method in class org.apache.flink.yarn.Utils
 
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
 
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
 
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
 
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.RollingSink
Sets the prefix of valid-length files.
setValidLengthSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Sets the suffix of valid-length files.
setValue(V) - Method in class org.apache.flink.graph.Edge
 
setValue(V) - Method in class org.apache.flink.graph.Vertex
 
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(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
 
setWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setWaitSec(int) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
This function sets how long TwitterSource should wait for the tweets.
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
 
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.RollingSink
Sets the Writer to be used for writing the incoming elements to bucket files.
ShardedConnection - Class in org.apache.flink.contrib.streaming.state
Helper class to maintain a sharded database connection and get Connections and PreparedStatements for keys.
ShardedConnection(List<String>, String, String, ShardedConnection.Partitioner) - Constructor for class org.apache.flink.contrib.streaming.state.ShardedConnection
 
ShardedConnection(List<String>, String, String) - Constructor for class org.apache.flink.contrib.streaming.state.ShardedConnection
 
ShardedConnection.ModHashPartitioner - Class in org.apache.flink.contrib.streaming.state
 
ShardedConnection.Partitioner - Interface in org.apache.flink.contrib.streaming.state
 
ShardedConnection.ShardedStatement - Class in org.apache.flink.contrib.streaming.state
 
ShardedStatement(String) - Constructor for class org.apache.flink.contrib.streaming.state.ShardedConnection.ShardedStatement
 
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
SharedBufferEdge(SharedBuffer.SharedBufferEntry<K, V>, DeweyNumber) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
SharedSlot - Class in org.apache.flink.runtime.instance
This class represents a shared slot.
SharedSlot(JobID, Instance, int, 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, Instance, int, 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.
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.examples.scala.TPCHQuery3Table.Lineitem
 
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.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_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
 
ShortComparator - Class in org.apache.flink.api.common.typeutils.base
 
ShortComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ShortComparator
 
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
 
ShortSum() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction.ShortSum
 
ShortSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
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.
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
 
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.
shouldIncludeFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
shouldIncludeRunning() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
shouldStartNewBucket(Path, Path) - Method in interface org.apache.flink.streaming.connectors.fs.Bucketer
Returns true when a new bucket should be started.
shouldStartNewBucket(Path, Path) - Method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
 
shouldStartNewBucket(Path, Path) - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
 
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.CliFrontend
 
shutdown() - Method in class org.apache.flink.client.program.Client
Shuts down the client.
shutdown() - Method in class org.apache.flink.runtime.blob.BlobCache
 
shutdown() - Method in class org.apache.flink.runtime.blob.BlobServer
Shuts down the BLOB server.
shutdown() - Method in interface org.apache.flink.runtime.blob.BlobService
Shutdown method which is called to terminate the blob service.
shutdown() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Shuts down the checkpoint coordinator.
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.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.scheduler.Scheduler
Shuts the scheduler down.
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.minicluster.FlinkMiniCluster
 
shutdown() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Forces an immediate shutdown of the thread.
shutdown() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
 
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(boolean) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Request the YARN cluster to shut down.
shutdown() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
shutdown(boolean) - Method in class org.apache.flink.yarn.FlinkYarnCluster
Shutdown the YARN cluster.
shutdownJobClientActorSystem(ActorSystem) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
SIDE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
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
 
SignatureVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
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.
SimpleCheckpointStatsTracker - Class in org.apache.flink.runtime.checkpoint.stats
A simple checkpoint stats tracker.
SimpleCheckpointStatsTracker(int, List<ExecutionJobVertex>) - Constructor for class org.apache.flink.runtime.checkpoint.stats.SimpleCheckpointStatsTracker
 
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
 
SimpleDistribution - Class in org.apache.flink.api.common.distributions
 
SimpleDistribution() - Constructor for class org.apache.flink.api.common.distributions.SimpleDistribution
 
SimpleDistribution(Key<?>[]) - Constructor for class org.apache.flink.api.common.distributions.SimpleDistribution
 
SimpleDistribution(Key<?>[][]) - Constructor for class org.apache.flink.api.common.distributions.SimpleDistribution
 
SimpleGradientDescent - Class in org.apache.flink.ml.optimization
Implementation of a SGD solver without regularization.
SimpleGradientDescent() - Constructor for class org.apache.flink.ml.optimization.SimpleGradientDescent
 
SimpleGradientDescent$ - Class in org.apache.flink.ml.optimization
 
SimpleGradientDescent$() - Constructor for class org.apache.flink.ml.optimization.SimpleGradientDescent$
 
SimpleIntegerDistribution - Class in org.apache.flink.api.common.distributions
 
SimpleIntegerDistribution() - Constructor for class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
 
SimpleIntegerDistribution(int[]) - Constructor for class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
 
SimpleIntegerDistribution(IntValue[]) - Constructor for class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
 
SimpleIntegerDistribution(IntValue[][]) - Constructor for class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
 
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
 
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, Instance, 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(JobID, Instance, int, 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..
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
 
SimpleStringUtils - Class in org.apache.flink.util
Utility class for efficient string operations on strings.
SimpleStringUtils.WhitespaceTokenizer - Class in org.apache.flink.util
A tokenizer for string values that uses whitespace characters as token delimiters.
SimpleTweetInputFormat - Class in org.apache.flink.contrib.tweetinputformat.io
 
SimpleTweetInputFormat() - Constructor for class org.apache.flink.contrib.tweetinputformat.io.SimpleTweetInputFormat
 
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
 
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, ExecutionAttemptID, IntermediateDataSetID, int, int, PartitionStateChecker) - 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
 
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.api.table.parser.ExpressionParser$
 
singleQuoteStringLiteral() - Static method in class org.apache.flink.api.table.parser.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> - 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> - Class in org.apache.flink.graph.library
 
SingleSourceShortestPaths.MinDistanceMessenger - Class in org.apache.flink.graph.examples
Distributes the minimum distance associated with a given vertex among all the target vertices summed up with the edge's value.
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 - Class in org.apache.flink.graph.examples
Function that updates the value of a vertex by picking the minimum distance from all incoming messages.
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.
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() - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
Returns the number of elements currently stored in the task's cache.
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 - 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.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.AbstractHeapState
Returns the number of all state pairs in this state, across namespaces.
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.connectors.kafka.internals.ClosableBlockingQueue
Gets the number of elements currently in the queue.
size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
 
size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
 
size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
 
size() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
Returns the number of elements that are currently in the buffer.
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.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.
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.local.LocalDataInputStream
 
skip(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
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.runtime.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
 
sleepInterval() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
sleepInterval() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
slidePanes(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
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) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
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 task slots.
Slot(JobID, Instance, int, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
Base constructor for slots.
slotAllocated(SimpleSlot) - Method in interface org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFutureAction
This method is called as soon as the SlotAllocationFuture is triggered.
SlotAllocationFuture - Class in org.apache.flink.runtime.jobmanager.scheduler
 
SlotAllocationFuture() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
 
SlotAllocationFuture(SimpleSlot) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
 
SlotAllocationFutureAction - Interface in org.apache.flink.runtime.jobmanager.scheduler
An action that is invoked once a SlotAllocationFuture is triggered.
SlotAvailabilityListener - Interface in org.apache.flink.runtime.jobmanager.scheduler
A SlotAvailabilityListener can be notified when new Slots become available on an Instance.
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.
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
 
snapshot(long, long) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
snapshot(long, long) - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
 
snapshot(long, long) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsState
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ACC>, FoldingStateDescriptor<T, ACC>, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsFoldingState.Snapshot
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ArrayList<V>>, ListStateDescriptor<V>, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsListState.Snapshot
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ReducingStateDescriptor<V>, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsReducingState.Snapshot
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ValueStateDescriptor<V>, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsValueState.Snapshot
 
snapshot(long, long) - Method in class org.apache.flink.runtime.state.GenericFoldingState
 
snapshot(long, long) - Method in class org.apache.flink.runtime.state.GenericListState
 
snapshot(long, long) - Method in class org.apache.flink.runtime.state.GenericReducingState
 
snapshot(long, long) - Method in interface org.apache.flink.runtime.state.KvState
Creates a snapshot of this state.
snapshot(long, long) - Method in class org.apache.flink.runtime.state.memory.AbstractMemState
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ACC>, FoldingStateDescriptor<T, ACC>, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.MemFoldingState.Snapshot
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ArrayList<V>>, ListStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.MemListState.Snapshot
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ReducingStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.MemReducingState.Snapshot
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ValueStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.MemValueState.Snapshot
 
snapshot(DataOutputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
 
snapshot(DataOutputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
 
snapshot(DataOutputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
 
snapshot(DataOutputView) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
Writes the contents of the window buffer to a DataOutputView for checkpointing.
snapshotOperatorState(long, long) - Method in class org.apache.flink.cep.operator.CEPPatternOperator
 
snapshotOperatorState(long, long) - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
snapshotOperatorState(long, long) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
Called to draw a state snapshot from the operator.
snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
 
snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
snapshotOperatorState(long, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
snapshotPartitionedState(long, long) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.Checkpointed
Gets the current state of the function of operator.
snapshotState(long, long) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
snapshotState(long, long) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
snapshotState(long, long) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
snapshotState(long, long) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
snapshotState(long, long) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
 
snapshotState(long, long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
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
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
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, char, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
SocketTextStreamFunction(String, int, char, long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
SocketTextStreamWordCount - Class in org.apache.flink.streaming.examples.socket
This example shows an implementation of WordCount with data from a text socket.
SocketTextStreamWordCount() - Constructor for class org.apache.flink.streaming.examples.socket.SocketTextStreamWordCount
 
SocketTextStreamWordCount - Class in org.apache.flink.streaming.scala.examples.socket
This example shows an implementation of WordCount with data from a text socket.
SocketTextStreamWordCount() - Constructor for class org.apache.flink.streaming.scala.examples.socket.SocketTextStreamWordCount
 
SocketTextStreamWordCount$ - Class in org.apache.flink.streaming.scala.examples.socket
This example shows an implementation of WordCount with data from a text socket.
SocketTextStreamWordCount$() - Constructor for class org.apache.flink.streaming.scala.examples.socket.SocketTextStreamWordCount$
 
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
 
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
 
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.
SortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
Creates a new sorting thread.
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) - 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.storm.util.InMemorySpout
 
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
 
sourceId() - Method in class org.apache.flink.examples.scala.PageRankTable.AdjacencyList
 
sourceId() - Method in class org.apache.flink.examples.scala.PageRankTable.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
Task for executing streaming sources.
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
 
SpanningRecordSerializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
SparseKeySchema - Class in org.apache.flink.optimizer.postpass
Class encapsulating a schema map (int column position -> column type) and a reference counter.
SparseKeySchema() - Constructor for class org.apache.flink.optimizer.postpass.SparseKeySchema
 
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
Element wise access function
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
 
speed() - Method in class org.apache.flink.examples.scala.StreamingTableFilter.CarEvent
 
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() - 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.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
 
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
 
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.
SQLRetrier - Class in org.apache.flink.contrib.streaming.state
Simple utility to retry failed SQL commands for a predefined number of times before declaring failure.
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
 
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(ActorSystem, int) - 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.ResponseStackTraceSampleFailure - Class in org.apache.flink.runtime.messages
Response after a failed stack trace sample (sent by the task managers to the job manager).
StackTraceSampleMessages.ResponseStackTraceSampleFailure$ - Class in org.apache.flink.runtime.messages
 
StackTraceSampleMessages.ResponseStackTraceSampleSuccess - Class in org.apache.flink.runtime.messages
Response after a successful stack trace sample (sent by the task managers to the job manager).
StackTraceSampleMessages.ResponseStackTraceSampleSuccess$ - Class in org.apache.flink.runtime.messages
 
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
 
StandaloneCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
CheckpointIDCounter instances for JobManagers running in RecoveryMode.STANDALONE.
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
 
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
Creates a StandaloneLeaderRetrievalService with the given JobManager address.
StandaloneSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
SubmittedJobGraph instances for JobManagers running in RecoveryMode.STANDALONE.
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
 
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.runtime.checkpoint.CheckpointIDCounter
Starts the CheckpointIDCounter service.
start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Starts the CheckpointRecoveryFactory service.
start() - Method in class org.apache.flink.runtime.checkpoint.SavepointStore
 
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(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
 
start(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
start(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
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(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(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.test.util.ForkableFlinkMiniCluster
 
startActor(Props, ActorSystem) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
 
startActor(Props, ActorSystem) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
startActorSystemAndJobManagerActors(Configuration, JobManagerMode, String, int, Class<? extends JobManager>, Class<? extends MemoryArchivist>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Starts an ActorSystem, the JobManager and all its components including the WebMonitor.
startActorSystemAndJobManagerActors(Configuration, JobManagerMode, String, int, Class<? extends JobManager>, Class<? extends MemoryArchivist>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Starts an ActorSystem, the JobManager and all its components including the WebMonitor.
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, String) - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster$
 
startCluster(int, int, String) - Static method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
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.runtime.util.ZooKeeperUtils
Starts a CuratorFramework instance and connects it to the given ZooKeeper quorum.
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
 
startJobManager(int, ActorSystem) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startJobManager(int, ActorSystem) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
startJobManager(int, ActorSystem) - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
startJobManagerActors(Configuration, ActorSystem, 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, 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(Configuration, ActorSystem, 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, 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
 
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.
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
 
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
 
startReading() - Method in class org.apache.flink.runtime.operators.TempBarrier
 
startRecord() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
startShell(String, int, Enumeration.Value, Option<String[]>) - Method in class org.apache.flink.api.scala.FlinkShell$
 
startShell(String, int, Enumeration.Value, Option<String[]>) - Static method in class org.apache.flink.api.scala.FlinkShell
 
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
 
startTaskManager(int, ActorSystem) - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
startTaskManagerActorSystem(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startTaskManagerComponentsAndActor(Configuration, ActorSystem, String, Option<String>, Option<LeaderRetrievalService>, boolean, Class<? extends TaskManager>) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
startTaskManagerComponentsAndActor(Configuration, ActorSystem, String, Option<String>, Option<LeaderRetrievalService>, boolean, Class<? extends TaskManager>) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
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.
STARTUP_CONNECT_LOG_SUPPRESS() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Time (milli seconds) after which the TaskManager will start logging failed connection attempts
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 connection attempts
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
startWebRuntimeMonitor(Configuration, LeaderRetrievalService, 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
 
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.runtime.messages.TaskMessages.PartitionState
 
state - Variable in class org.apache.flink.runtime.state.AbstractHeapState
Map containing the actual key/value pairs
state - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
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
State backend for checkpoints;
StateBackend - Interface in org.apache.flink.api.common.state
The StateBackend is used by StateDescriptor instances to create actual state representations.
StateBackendFactory<T extends AbstractStateBackend> - Interface in org.apache.flink.runtime.state
A factory to create a specific state backend.
stateDesc - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState.AbstractRocksDBSnapshot
Hash of the StateDescriptor, for sanity checks
stateDesc - Variable in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
This holds the name of the state and can create an initial default value for the state.
stateDesc - Variable in class org.apache.flink.contrib.streaming.state.RocksDBListState
This holds the name of the state and can create an initial default value for the state.
stateDesc - Variable in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
This holds the name of the state and can create an initial default value for the state.
stateDesc - Variable in class org.apache.flink.contrib.streaming.state.RocksDBValueState
This holds the name of the state and can create an initial default value for the state.
stateDesc - Variable in class org.apache.flink.runtime.state.AbstractHeapState
This holds the name of the state and can create an initial default value for the state.
stateDesc - Variable in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
StateDescriptor, for sanity checks
stateDesc - Variable in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
StateDescriptor, for sanity checks
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.
StateForTask - Class in org.apache.flink.runtime.checkpoint
Simple bean to describe the state belonging to a parallel operator.
StateForTask(SerializedValue<StateHandle<?>>, long, JobVertexID, int, long) - Constructor for class org.apache.flink.runtime.checkpoint.StateForTask
 
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<T extends StateHandle<?>> - 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<T> - Interface in org.apache.flink.runtime.state
StateHandle is a general handle interface meant to abstract operator state fetching.
stateSerializer - Variable in class org.apache.flink.runtime.state.AbstractHeapState
Serializer for the state value.
stateSerializer - Variable in class org.apache.flink.runtime.state.filesystem.AbstractFsStateSnapshot
Serializer for the state value
stateSerializer - Variable in class org.apache.flink.runtime.state.memory.AbstractMemStateSnapshot
Serializer for the state value
stateSerializer() - Method in interface org.apache.flink.streaming.api.scala.function.StatefulFunction
 
StateStorageHelper<T extends Serializable> - Interface in org.apache.flink.runtime.zookeeper
State storage helper which is used by ZooKeeperStateHandleStore to persiste state before the state handle is written to ZooKeeper.
StateStore<T extends Serializable> - Interface in org.apache.flink.runtime.checkpoint
A simple org.apache.flink.runtime.state.StateBackend backend object store interface.
StateTransition<T> - Class in org.apache.flink.cep.nfa
 
StateTransition(StateTransitionAction, State<T>, FilterFunction<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.
StateUtils - Class in org.apache.flink.runtime.state
A collection of utility methods for dealing with operator state.
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) - Constructor for class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
 
StaticFileServerHandler(JobManagerRetriever, Future<String>, FiniteDuration, File, Logger) - Constructor for class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
 
statisticsKey - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
status() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CurrentJobStatus
 
status() - Method in class org.apache.flink.yarn.YarnMessages.LocalStopYarnSession
 
status() - Method in class org.apache.flink.yarn.YarnMessages.StopYarnSession
 
statuses() - Method in class org.apache.flink.yarn.YarnMessages.YarnContainersCompleted
 
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
 
std() - Method in class org.apache.flink.ml.preprocessing.StandardScaler.StandardScalerTransformOperation
 
Std$() - Constructor for class org.apache.flink.ml.preprocessing.StandardScaler.Std$
 
stdOutFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
 
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$
 
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.FlinkYarnSessionCli
Utility method for tests.
stop() - Method in class org.apache.flink.client.LocalExecutor
 
stop(JobID) - Method in class org.apache.flink.client.program.Client
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() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Stops the CheckpointIDCounter service.
stop() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Stops the CheckpointRecoveryFactory service.
stop() - Method in class org.apache.flink.runtime.checkpoint.SavepointStore
 
stop() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
stop() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
stop() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
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.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 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.StoppableStreamSource
Marks the source a stopped and calls StoppableFunction.stop() on the user function.
stop() - Method in class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
 
stop() - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
stopAfterJob(JobID) - Method in class org.apache.flink.runtime.yarn.AbstractFlinkYarnCluster
Tells the ApplicationMaster to monitor the status of JobId and stop itself once the specified job has finished.
stopAfterJob(JobID) - Method in class org.apache.flink.yarn.FlinkYarnCluster
 
StopAMAfterJob(JobID) - Constructor for class org.apache.flink.yarn.YarnMessages.StopAMAfterJob
 
StopAMAfterJob$() - Constructor for class org.apache.flink.yarn.YarnMessages.StopAMAfterJob$
 
stopCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
stopCluster() - Method in class org.apache.flink.test.util.AbstractTestBase
 
stopCluster(ForkableFlinkMiniCluster, FiniteDuration) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
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
 
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.
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$
 
stopRunner() - Method in class org.apache.flink.yarn.FlinkYarnCluster.PollingThread
 
StopTask(ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.StopTask
 
StopTask$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.StopTask$
 
stopWhenJobFinished() - Method in class org.apache.flink.yarn.YarnJobManager
 
stopWithError(Throwable) - Method in interface org.apache.flink.streaming.connectors.kafka.internals.Fetcher
Exit run loop with given error and release all resources.
stopWithError(Throwable) - Method in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher
Reports an error from a fetch thread.
StopYarnSession(FinalApplicationStatus, String) - Constructor for class org.apache.flink.yarn.YarnMessages.StopYarnSession
 
StopYarnSession$() - Constructor for class org.apache.flink.yarn.YarnMessages.StopYarnSession$
 
store(T) - Method in class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
 
store(T) - Method in interface org.apache.flink.runtime.zookeeper.StateStorageHelper
Stores the given state and returns a state handle to it.
storeElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.FoldingWindowBuffer
 
storeElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ListWindowBuffer
 
storeElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.buffers.ReducingWindowBuffer
 
storeElement(StreamRecord<T>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.buffers.WindowBuffer
Adds the element to the buffer.
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.api.table.expressions.Substring
 
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, Iterator, Collector) - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
Sends all values contained in both iterators to the external process and collects all results.
streamBufferWithoutGroups(Iterator, Collector) - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
Sends all values contained in the iterator to the external process and collects all results.
StreamConfig - Class in org.apache.flink.streaming.api.graph
 
StreamConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig
 
StreamContextEnvironment - Class in org.apache.flink.streaming.api.environment
 
StreamContextEnvironment(ContextEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamContextEnvironment
 
StreamCounter<IN> - Class in org.apache.flink.streaming.api.operators
 
StreamCounter() - Constructor for class org.apache.flink.streaming.api.operators.StreamCounter
 
StreamEdge - Class in org.apache.flink.streaming.api.graph
An edge in the streaming topology.
StreamEdge(StreamNode, StreamNode, int, List<String>, StreamPartitioner<?>) - 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
 
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.
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
 
StreamGraph.ResourceStrategy - Enum in org.apache.flink.streaming.api.graph
 
StreamGraphGenerator - Class in org.apache.flink.streaming.api.graph
A generator that generates a StreamGraph from a graph of StreamTransformations.
StreamGroupedFold<IN,OUT,KEY> - Class in org.apache.flink.streaming.api.operators
 
StreamGroupedFold(FoldFunction<IN, OUT>, OUT) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedFold
 
StreamGroupedReduce<IN> - Class in org.apache.flink.streaming.api.operators
 
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.TwitterStreamData
 
STREAMING_COUNTS_AS_TUPLES - Static variable in class org.apache.flink.test.testdata.WordCountData
 
StreamingJobGraphGenerator - Class in org.apache.flink.streaming.api.graph
 
StreamingJobGraphGenerator(StreamGraph) - Constructor for class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
StreamingPlan - Class in org.apache.flink.optimizer.plan
Abstract class representing Flink Streaming plans
StreamingPlan() - Constructor for class org.apache.flink.optimizer.plan.StreamingPlan
 
StreamingReader - Interface in org.apache.flink.streaming.runtime.io
 
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
 
StreamingTableFilter - Class in org.apache.flink.examples.scala
Simple example for demonstrating the use of the Table API with Flink Streaming.
StreamingTableFilter() - Constructor for class org.apache.flink.examples.scala.StreamingTableFilter
 
StreamingTableFilter$ - Class in org.apache.flink.examples.scala
Simple example for demonstrating the use of the Table API with Flink Streaming.
StreamingTableFilter$() - Constructor for class org.apache.flink.examples.scala.StreamingTableFilter$
 
StreamingTableFilter.CarEvent - Class in org.apache.flink.examples.scala
 
StreamingTableFilter.CarEvent$ - Class in org.apache.flink.examples.scala
 
StreamInputProcessor<IN> - Class in org.apache.flink.streaming.runtime.io
Input reader for OneInputStreamTask.
StreamInputProcessor(InputGate[], TypeSerializer<IN>, EventListener<CheckpointBarrier>, CheckpointingMode, IOManager, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
StreamIterationHead<OUT> - Class in org.apache.flink.streaming.runtime.tasks
 
StreamIterationHead() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
StreamIterationTail<IN> - Class in org.apache.flink.streaming.runtime.tasks
 
StreamIterationTail() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
 
StreamMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
 
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
 
StreamPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
StreamPlanEnvironment - Class in org.apache.flink.streaming.api.environment
 
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, boolean, StringBuilder) - Constructor for class org.apache.flink.python.api.streaming.util.StreamPrinter
 
StreamProject<IN,OUT extends Tuple> - Class in org.apache.flink.streaming.api.operators
 
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
 
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
 
StreamRecordSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
Serializer for StreamRecord.
StreamRecordSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecordSerializer
 
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
 
StreamSink<IN> - Class in org.apache.flink.streaming.api.operators
 
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
 
StreamSource.AutomaticWatermarkContext<T> - Class in org.apache.flink.streaming.api.operators
SourceFunction.SourceContext to be used for sources with automatic timestamps and watermark emission.
StreamSource.ManualWatermarkContext<T> - Class in org.apache.flink.streaming.api.operators
A SourceContext for event time.
StreamSource.NonTimestampContext<T> - Class in org.apache.flink.streaming.api.operators
A source context that attached -1 as a timestamp to all records, and that does not forward watermarks.
StreamStateHandle - Interface in org.apache.flink.runtime.state
A state handle that produces an input stream when resolved.
StreamTask<OUT,Operator 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.streaming.runtime.tasks
The state checkpointed by a AbstractStreamOperator.
StreamTaskState() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskState
 
StreamTaskStateList - Class in org.apache.flink.streaming.runtime.tasks
List of task states for a chain of streaming tasks.
StreamTaskStateList(StreamTaskState[]) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskStateList
 
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>, EventListener<CheckpointBarrier>, CheckpointingMode, IOManager, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
StrictlyLocalAssignment - Interface in org.apache.flink.api.common.io
 
string2Literal(String) - Method in interface org.apache.flink.api.scala.table.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_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
 
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
 
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
 
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.
stringifyException(Throwable) - Static method in class org.apache.flink.util.StringUtils
Makes a string representation of the exception.
stringLiteralFlink() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
stringLiteralFlink() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
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
 
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.
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
 
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.
stub - Variable in class org.apache.flink.runtime.operators.BatchTask
The instantiated user code of this task's main operator (driver).
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, ListeningBehaviour) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.SubmitJob
 
SubmitJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.SubmitJob$
 
submitJobAndWait(ActorSystem, LeaderRetrievalService, 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(JobGraph, boolean, FiniteDuration, LeaderRetrievalService) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
SubmitJobAndWait$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobAndWait$
 
submitJobDetached(ActorGateway, JobGraph, FiniteDuration, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
Submits a job in detached mode.
SubmitJobDetached(JobGraph) - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobDetached
 
submitJobDetached(JobGraph) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
SubmitJobDetached$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobDetached$
 
SubmitTask(TaskDeploymentDescriptor) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.SubmitTask
 
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
subscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
 
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
 
substring(Expression, Expression) - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
Substring - Class in org.apache.flink.api.table.expressions
 
Substring(Expression, Expression, Expression) - Constructor for class org.apache.flink.api.table.expressions.Substring
 
substring() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
substring() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
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.api.table.expressions
 
Substring$() - Constructor for class org.apache.flink.api.table.expressions.Substring$
 
substringWithoutEnd() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
substringWithoutEnd() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
SubtaskCurrentAttemptDetailsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler providing details about a single task execution attempt.
SubtaskCurrentAttemptDetailsHandler(ExecutionGraphHolder) - 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
 
SubtaskExecutionAttemptDetailsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler providing details about a single task execution attempt.
SubtaskExecutionAttemptDetailsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptDetailsHandler
 
subtaskIndex() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
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
 
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
 
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 operator.
SubtypeFilterFunction<T> - Class in org.apache.flink.cep.pattern
A filter function which filters elements of the given type.
SubtypeFilterFunction(Class<? extends T>) - Constructor for class org.apache.flink.cep.pattern.SubtypeFilterFunction
 
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() - Method in class org.apache.flink.runtime.messages.TaskMessages.TaskOperationResult
 
suffix() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
suffix() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
suffix(String) - Method in class org.apache.flink.core.fs.Path
Adds a suffix to the final name in the path.
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) - 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() - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionOperations
 
Sum - Class in org.apache.flink.api.table.expressions
 
Sum(Expression) - Constructor for class org.apache.flink.api.table.expressions.Sum
 
SUM() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
sum() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
SUM() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
sum() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
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 that gives the current sum of the pojo data stream at the given field expressionby 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$ - Class in org.apache.flink.api.table.expressions
 
Sum$() - Constructor for class org.apache.flink.api.table.expressions.Sum$
 
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
 
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
 
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
 
SumFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
SumFunction.ByteSum - Class in org.apache.flink.streaming.api.functions.aggregation
 
SumFunction.DoubleSum - Class in org.apache.flink.streaming.api.functions.aggregation
 
SumFunction.FloatSum - Class in org.apache.flink.streaming.api.functions.aggregation
 
SumFunction.IntSum - Class in org.apache.flink.streaming.api.functions.aggregation
 
SumFunction.LongSum - Class in org.apache.flink.streaming.api.functions.aggregation
 
SumFunction.ShortSum - Class in org.apache.flink.streaming.api.functions.aggregation
 
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.
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
 
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
 
supportsCompareAgainstReference() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
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.EnumComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
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.PojoComparator
 
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.table.typeinfo.NullAwareComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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.StringComparator
 
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.PojoComparator
 
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.table.typeinfo.NullAwareComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 
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) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Swap items at the given addresses.
swap(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
 
symbol2FieldExpression(Symbol) - Method in interface org.apache.flink.api.scala.table.ImplicitExpressionConversions
 
SymbolExpression(Symbol) - Constructor for class org.apache.flink.api.scala.table.ImplicitExpressionConversions.SymbolExpression
 
sync() - Method in class org.apache.flink.core.fs.FSDataOutputStream
 
sync() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
sync() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
 
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
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
 

T

table - Variable in class org.apache.flink.addons.hbase.TableInputFormat
 
Table - Class in org.apache.flink.api.table
The abstraction for writing Table API programs.
Table(PlanNode) - Constructor for class org.apache.flink.api.table.Table
 
Table$ - Class in org.apache.flink.api.table
 
Table$() - Constructor for class org.apache.flink.api.table.Table$
 
TableConfig - Class in org.apache.flink.api.table
A config to define the runtime behavior of the Table API.
TableConfig() - Constructor for class org.apache.flink.api.table.TableConfig
 
TableConfig$ - Class in org.apache.flink.api.table
 
TableConfig$() - Constructor for class org.apache.flink.api.table.TableConfig$
 
TableConversions - Class in org.apache.flink.api.scala.table
Methods for converting a Table to a DataSet or DataStream.
TableConversions(Table) - Constructor for class org.apache.flink.api.scala.table.TableConversions
 
TableEnvironment - Class in org.apache.flink.api.java.table
Environment for working with the Table API.
TableEnvironment() - Constructor for class org.apache.flink.api.java.table.TableEnvironment
 
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.
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
 
takeNext(BlockingQueue<UnilateralSortMerger.CircularElement<E>>, Queue<UnilateralSortMerger.CircularElement<E>>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
takeStep(Vector, Vector, 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.GradientDescentL1
Calculates the new weights based on the gradient.
takeStep(Vector, Vector, double, double) - Method in class org.apache.flink.ml.optimization.GradientDescentL2
Calculates the new weights based on the gradient
takeStep(Vector, Vector, double, double) - Method in class org.apache.flink.ml.optimization.SimpleGradientDescent
Calculates the new weights based on the gradient.
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
 
targetId() - Method in class org.apache.flink.examples.scala.PageRankTable.Link
 
targetIds() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.AdjacencyList
 
targetIds() - Method in class org.apache.flink.examples.scala.PageRankTable.AdjacencyList
 
targetIds() - Method in class org.apache.flink.examples.scala.PageRankTable.RankOutput
 
Task - Class in org.apache.flink.runtime.taskmanager
The Task represents one execution of a parallel subtask on a TaskManager.
Task(TaskDeploymentDescriptor, MemoryManager, IOManager, NetworkEnvironment, BroadcastVariableManager, ActorGateway, ActorGateway, FiniteDuration, LibraryCacheManager, FileCache, TaskManagerRuntimeInfo) - 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_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_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_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_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_MAX_REGISTRATION_DURATION - Static variable in class org.apache.flink.configuration.ConfigConstants
 
TASK_MANAGER_MEMORY_FRACTION_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the fraction of free memory allocated by the memory manager.
TASK_MANAGER_MEMORY_OFF_HEAP_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the memory allocation method (JVM heap or off-heap).
TASK_MANAGER_MEMORY_PRE_ALLOCATE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter for specifying whether TaskManager managed memory should be preallocated when the TaskManager is starting.
TASK_MANAGER_MEMORY_SEGMENT_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Config parameter defining the size of memory buffers used by the network stack and the memory manager.
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
The config parameter defining the amount of memory to be allocated by the task manager's memory manager (in megabytes).
TASK_MANAGER_NAME() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
The name of the TaskManager actor
TASK_MANAGER_NAME() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
The name of the TaskManager actor
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
The config parameter defining the number of buffers used in the network stack.
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_TMP_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the directories for temporary files.
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.
TaskConfig.DelegatingConfiguration - Class in org.apache.flink.runtime.operators.util
A configuration that manages a subset of keys with a common prefix from a 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(JobID, JobVertexID, ExecutionAttemptID, String, int, int, int, Configuration, Configuration, String, List<ResultPartitionDeploymentDescriptor>, List<InputGateDeploymentDescriptor>, List<BlobKey>, List<URL>, int, SerializedValue<StateHandle<?>>, long) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Constructs a task deployment descriptor.
TaskDeploymentDescriptor(JobID, JobVertexID, ExecutionAttemptID, String, int, int, int, Configuration, Configuration, String, List<ResultPartitionDeploymentDescriptor>, List<InputGateDeploymentDescriptor>, List<BlobKey>, List<URL>, int) - 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
 
taskExecutionId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionState
 
taskExecutionId() - Method in class org.apache.flink.runtime.messages.TaskMessages.PartitionState
 
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) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
Creates a new task execution state update, with an attached exception.
taskID - Variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
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) - Constructor for class org.apache.flink.api.common.TaskInfo
 
TaskInputSplitProvider - Class in org.apache.flink.runtime.taskmanager
 
TaskInputSplitProvider(ActorGateway, JobID, JobVertexID, ExecutionAttemptID, ClassLoader, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
 
TaskManager - Class in org.apache.flink.runtime.taskmanager
The TaskManager is responsible for executing the individual tasks of a Flink job.
TaskManager(TaskManagerConfiguration, InstanceConnectionInfo, MemoryManager, IOManager, NetworkEnvironment, int, LeaderRetrievalService) - 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$
 
taskManagerActors() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
taskManagerActorSystems() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
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.taskmanager
 
TaskManagerConfiguration(String[], long, FiniteDuration, Option<FiniteDuration>, int, Configuration) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerConfiguration
 
TaskManagerConfiguration$ - Class in org.apache.flink.runtime.taskmanager
 
TaskManagerConfiguration$() - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerConfiguration$
 
TaskManagerInstance(Option<Instance>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TaskManagerInstance
 
TaskManagerInstance$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TaskManagerInstance$
 
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.NotifyWhenRegisteredAtAnyJobManager$ - Class in org.apache.flink.runtime.messages
Requests a notification from the task manager as soon as the task manager has been registered at any 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.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
 
taskManagerNumSlots - Variable in class org.apache.flink.test.util.AbstractTestBase
 
taskManagerRunnerClass() - Method in class org.apache.flink.yarn.YarnJobManager
 
TaskManagerRuntimeInfo - Class in org.apache.flink.runtime.taskmanager
Encapsulation of TaskManager runtime information, like hostname and configuration.
TaskManagerRuntimeInfo(String, Configuration) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Creates a runtime info.
taskManagers() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers
 
TaskManagersHandler - Class in org.apache.flink.runtime.webmonitor.handlers
 
TaskManagersHandler(FiniteDuration) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.TaskManagersHandler
 
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.PartitionState - Class in org.apache.flink.runtime.messages
Answer to a RequestPartitionState with the state of the respective partition.
TaskMessages.PartitionState$ - 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.TaskOperationResult - Class in org.apache.flink.runtime.messages
Response message to updates in the task state.
TaskMessages.TaskOperationResult$ - Class in org.apache.flink.runtime.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
 
TaskMessages.UpdateTaskMultiplePartitionInfos$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.UpdateTaskSinglePartitionInfo - Class in org.apache.flink.runtime.messages
 
TaskMessages.UpdateTaskSinglePartitionInfo$ - Class in org.apache.flink.runtime.messages
 
taskName() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
taskName - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
taskNumber - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
TaskOperationResult(ExecutionAttemptID, boolean, String) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.TaskOperationResult
 
TaskOperationResult(ExecutionAttemptID, boolean) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.TaskOperationResult
 
TaskOperationResult$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.TaskOperationResult$
 
taskResultId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionState
 
taskResultId() - Method in class org.apache.flink.runtime.messages.TaskMessages.PartitionState
 
tasks() - Method in class org.apache.flink.runtime.messages.TaskMessages.SubmitTask
 
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.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.
TemporaryPath$() - Constructor for class org.apache.flink.ml.recommendation.ALS.TemporaryPath$
 
term() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
term() - Static method in class org.apache.flink.api.table.parser.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
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
 
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
 
TestEnvironment - Class in org.apache.flink.test.util
 
TestEnvironment(ForkableFlinkMiniCluster, int) - Constructor for class org.apache.flink.test.util.TestEnvironment
 
TestEnvironment(ForkableFlinkMiniCluster, 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
 
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
 
testProgram() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
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.TwitterStreamData
 
TextValueInputFormat - Class in org.apache.flink.api.java.io
 
TextValueInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextValueInputFormat
 
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$
 
throwableSerializer() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
time() - Method in class org.apache.flink.examples.scala.StreamingTableFilter.CarEvent
 
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.join.WindowJoin.Grade
 
time() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Salary
 
time() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent
 
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).
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
 
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() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerConfiguration
 
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
 
timestamp() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
timestamp() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged
 
timestamp - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
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.NonKeyedWindowOperator
This is given to the WindowFunction for emitting elements with a given timestamp.
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.
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
 
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 start + size (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
 
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.
tmpDirPaths() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerConfiguration
 
to - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
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.types.ListValue
 
toArray(T[]) - Method in class org.apache.flink.types.ListValue
 
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
 
toCompletedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
toDataSet(Table, Class<T>) - Method in class org.apache.flink.api.java.table.TableEnvironment
Converts the given Table to a DataSet.
toDataSet(TypeInformation<T>) - Method in class org.apache.flink.api.scala.table.TableConversions
Converts the Table to a DataSet.
toDataStream(Table, Class<T>) - Method in class org.apache.flink.api.java.table.TableEnvironment
Converts the given Table to a DataStream.
toDataStream(TypeInformation<T>) - Method in class org.apache.flink.api.scala.table.TableConversions
Converts the Table to a DataStream.
toDenseMatrix() - Method in class org.apache.flink.ml.math.SparseMatrix
 
toDenseVector() - Method in class org.apache.flink.ml.math.SparseVector
 
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
 
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
 
toISC(StringContext) - Method in class org.apache.flink.api.table.codegen.Indenter$
 
toISC(StringContext) - Static method in class org.apache.flink.api.table.codegen.Indenter
 
toJobExecutionResult(ClassLoader) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
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.wordcount.PojoExample.Tokenizer
 
Tokenizer() - Constructor for class org.apache.flink.streaming.examples.wordcount.WordCount.Tokenizer
 
toLocalInputChannel() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
 
toLowerCase(StringValue) - Static method in class org.apache.flink.util.SimpleStringUtils
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
 
toMilliseconds() - Method in class org.apache.flink.streaming.api.windowing.time.Time
Converts the time interval to milliseconds.
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
 
topicId - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
The name of the topic this producer is writing data to
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
 
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
 
toRemoteInputChannel(ConnectionID) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
 
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
toSerializableHandle() - Method in class org.apache.flink.runtime.state.filesystem.FileStreamStateHandle
 
toSerializableHandle() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
toSerializableHandle() - Method in interface org.apache.flink.runtime.state.StreamStateHandle
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
 
toSparseVector() - Method in class org.apache.flink.ml.math.DenseVector
 
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.Histogram
 
toString() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
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.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.SingleInputSemanticProperties
 
toString() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
toString() - Method in class org.apache.flink.api.common.state.StateDescriptor
 
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.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.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.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.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.api.table.expressions.Abs
 
toString() - Method in class org.apache.flink.api.table.expressions.Aggregation
 
toString() - Method in class org.apache.flink.api.table.expressions.And
 
toString() - Method in class org.apache.flink.api.table.expressions.Avg
 
toString() - Method in class org.apache.flink.api.table.expressions.BitwiseAnd
 
toString() - Method in class org.apache.flink.api.table.expressions.BitwiseNot
 
toString() - Method in class org.apache.flink.api.table.expressions.BitwiseOr
 
toString() - Method in class org.apache.flink.api.table.expressions.BitwiseXor
 
toString() - Method in class org.apache.flink.api.table.expressions.Cast
 
toString() - Method in class org.apache.flink.api.table.expressions.Count
 
toString() - Method in class org.apache.flink.api.table.expressions.Div
 
toString() - Method in class org.apache.flink.api.table.expressions.EqualTo
 
toString() - Method in class org.apache.flink.api.table.expressions.GreaterThan
 
toString() - Method in class org.apache.flink.api.table.expressions.GreaterThanOrEqual
 
toString() - Method in class org.apache.flink.api.table.expressions.IsNotNull
 
toString() - Method in class org.apache.flink.api.table.expressions.IsNull
 
toString() - Method in class org.apache.flink.api.table.expressions.LessThan
 
toString() - Method in class org.apache.flink.api.table.expressions.LessThanOrEqual
 
toString() - Method in class org.apache.flink.api.table.expressions.Literal
 
toString() - Method in class org.apache.flink.api.table.expressions.Max
 
toString() - Method in class org.apache.flink.api.table.expressions.Min
 
toString() - Method in class org.apache.flink.api.table.expressions.Minus
 
toString() - Method in class org.apache.flink.api.table.expressions.Mod
 
toString() - Method in class org.apache.flink.api.table.expressions.Mul
 
toString() - Method in class org.apache.flink.api.table.expressions.Naming
 
toString() - Method in class org.apache.flink.api.table.expressions.Not
 
toString() - Method in class org.apache.flink.api.table.expressions.NotEqualTo
 
toString() - Method in class org.apache.flink.api.table.expressions.Or
 
toString() - Method in class org.apache.flink.api.table.expressions.Plus
 
toString() - Method in class org.apache.flink.api.table.expressions.ResolvedFieldReference
 
toString() - Method in class org.apache.flink.api.table.expressions.Substring
 
toString() - Method in class org.apache.flink.api.table.expressions.Sum
 
toString() - Method in class org.apache.flink.api.table.expressions.UnaryMinus
 
toString() - Method in class org.apache.flink.api.table.expressions.UnresolvedFieldReference
 
toString() - Method in class org.apache.flink.api.table.plan.Aggregate
 
toString() - Method in class org.apache.flink.api.table.plan.As
 
toString() - Method in class org.apache.flink.api.table.plan.Filter
 
toString() - Method in class org.apache.flink.api.table.plan.GroupBy
 
toString() - Method in class org.apache.flink.api.table.plan.Join
 
toString() - Method in class org.apache.flink.api.table.plan.Root
 
toString() - Method in class org.apache.flink.api.table.plan.Select
 
toString() - Method in class org.apache.flink.api.table.plan.UnionAll
 
toString() - Method in class org.apache.flink.api.table.Row
 
toString() - Method in class org.apache.flink.api.table.Table
 
toString() - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
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.Configuration
 
toString() - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.CountMinHeavyHitter
 
toString() - Method in interface org.apache.flink.contrib.operatorstatistics.heavyhitters.HeavyHitter
 
toString() - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.LossyCounting
 
toString() - Method in class org.apache.flink.contrib.operatorstatistics.OperatorStatistics
 
toString() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Coordinates
 
toString() - Method in class org.apache.flink.core.fs.FileInputSplit
 
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.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.JavaTableExample.WC
 
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.examples.EuclideanGraphWeighing.Point
 
toString() - Method in class org.apache.flink.graph.examples.utils.ExampleUtils.PrintingOutputFormatWithMessage
 
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.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.optimizer.postpass.SparseKeySchema
 
toString() - Method in class org.apache.flink.python.api.PythonOperationInfo.AggregationEntry
 
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.CompletedCheckpoint
 
toString() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
toString() - Method in class org.apache.flink.runtime.checkpoint.StateForTask
 
toString() - Method in class org.apache.flink.runtime.checkpoint.stats.CheckpointStats
 
toString() - Method in class org.apache.flink.runtime.checkpoint.stats.OperatorCheckpointStats
 
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.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.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.InstanceConnectionInfo
 
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.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.consumer.UnknownInputChannel
 
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.tasks.JobSnapshottingSettings
 
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.SlotAllocationFuture
 
toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
toString() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
 
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.StackTraceSampleMessages.ResponseStackTraceSampleSuccess
 
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.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.operators.util.TaskConfig.DelegatingConfiguration
 
toString() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
toString() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
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.util.DataOutputSerializer
 
toString() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
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.runtime.yarn.FlinkYarnClusterStatus
 
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 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.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.transformations.StreamTransformation
 
toString() - Method in class org.apache.flink.streaming.api.watermark.Watermark
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
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.DateTimeBucketer
 
toString() - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
 
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.metrics.DefaultKafkaMetricAccumulator
 
toString() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
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
 
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.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.HashPartitioner
 
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.StreamRecord
 
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() - 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.Pair
 
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.SerializedValue
 
toTable() - Method in class org.apache.flink.api.scala.table.DataSetConversions
Converts the DataSet to a Table.
toTable() - Method in class org.apache.flink.api.scala.table.DataStreamConversions
Converts the DataStream to a Table.
totalNumberOfSubTasks() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
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.java8.relational
This program implements a modified version of the TPC-H query 10.
TPCHQuery10() - Constructor for class org.apache.flink.examples.java8.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.examples.scala
This program implements a modified version of the TPC-H query 3.
TPCHQuery3Table() - Constructor for class org.apache.flink.examples.scala.TPCHQuery3Table
 
TPCHQuery3Table$ - Class in org.apache.flink.examples.scala
This program implements a modified version of the TPC-H query 3.
TPCHQuery3Table$() - Constructor for class org.apache.flink.examples.scala.TPCHQuery3Table$
 
TPCHQuery3Table.Customer - Class in org.apache.flink.examples.scala
 
TPCHQuery3Table.Customer$ - Class in org.apache.flink.examples.scala
 
TPCHQuery3Table.Lineitem - Class in org.apache.flink.examples.scala
 
TPCHQuery3Table.Lineitem$ - Class in org.apache.flink.examples.scala
 
TPCHQuery3Table.Order - Class in org.apache.flink.examples.scala
 
TPCHQuery3Table.Order$ - Class in org.apache.flink.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.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.api.table.expressions.Cast
 
tpe() - Method in class org.apache.flink.api.table.expressions.Literal
 
tpe() - Method in class org.apache.flink.api.table.expressions.ResolvedFieldReference
 
tpe() - Method in class org.apache.flink.api.table.typeinfo.RenamingProxyTypeInfo
 
trackTerm(String) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets which term to track.
trackTerms(Collection<String>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
This function sets which terms to track.
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(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.
transformation - Variable in class org.apache.flink.streaming.api.datastream.DataStream
 
transformations - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
transformChildrenPost(PartialFunction<A, A>) - Method in class org.apache.flink.api.table.trees.TreeNode
 
transformChildrenPre(PartialFunction<A, A>) - Method in class org.apache.flink.api.table.trees.TreeNode
 
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.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.
transformPost(PartialFunction<A, A>) - Method in class org.apache.flink.api.table.trees.TreeNode
 
transformPre(PartialFunction<A, A>) - Method in class org.apache.flink.api.table.trees.TreeNode
 
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.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(PlanNode, TypeInformation<A>) - Method in class org.apache.flink.api.java.table.JavaBatchTranslator
 
translate(PlanNode, TypeInformation<A>) - Method in class org.apache.flink.api.java.table.JavaStreamingTranslator
 
translate(PlanNode, TypeInformation<O>) - Method in class org.apache.flink.api.scala.table.ScalaBatchTranslator
 
translate(PlanNode, TypeInformation<O>) - Method in class org.apache.flink.api.scala.table.ScalaStreamingTranslator
 
translate(PlanNode, TypeInformation<A>) - Method in class org.apache.flink.api.table.plan.PlanTranslator
Translates the given Table API PlanNode back to the underlying representation, i.e, a DataSet or a DataStream.
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
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.table.typeinfo.RenameOperator
 
translateToPlan(List<DataSink<?>>, String) - Method in class org.apache.flink.api.java.operators.OperatorTranslation
 
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
 
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.
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.api.table.trees
Generic base class for trees that can be transformed and traversed.
TreeNode() - Constructor for class org.apache.flink.api.table.trees.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
 
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
 
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(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(long) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
Deprecated.
 
trigger(long) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
trigger(long) - Method in interface org.apache.flink.streaming.runtime.operators.Triggerable
This method is invoked with the timestamp for which the trigger was scheduled.
trigger(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
 
trigger(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
 
trigger - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
trigger(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
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 - Interface in org.apache.flink.streaming.runtime.operators
This interface must be implemented by objects that are triggered by the timer service available to stream operators in StreamExecutionEnvironment.
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) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Triggers a new checkpoint and uses the given timestamp as the checkpoint timestamp.
triggerCheckpoint(long, long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Triggers a new checkpoint and uses the given timestamp as the checkpoint timestamp.
triggerCheckpoint(long, long) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
This method is either called directly and asynchronously by the checkpoint coordinator (in the case of functions that are directly notified - usually the data sources), or called synchronously when all incoming channels have reported a checkpoint barrier.
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) - Constructor for class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
triggerCheckpoint(long, long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
triggerCheckpointBarrier(long, long) - Method in class org.apache.flink.runtime.taskmanager.Task
Calls the invokable to trigger a checkpoint, if the invokable implements the interface StatefulTask.
triggerMeters() - Method in class org.apache.flink.examples.scala.StreamingTableFilter$
 
triggerMeters() - Static method in class org.apache.flink.examples.scala.StreamingTableFilter
 
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
 
triggerPartitionStateCheck(JobID, ExecutionAttemptID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.io.network.netty.PartitionStateChecker
 
TriggerResult - Enum in org.apache.flink.streaming.api.windowing.triggers
Result type for trigger methods.
triggerSavepoint(long) - Method in class org.apache.flink.runtime.checkpoint.SavepointCoordinator
Triggers a new savepoint using the current system time as the checkpoint timestamp.
TriggerSavepoint(JobID) - 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, String) - 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, FiniteDuration, 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, FiniteDuration, 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(String, FiniteDuration, Option<Deadline>, int) - 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$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration$
 
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 - Static variable in class org.apache.flink.types.BooleanValue
 
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
 
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
 
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
 
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) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
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
 
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
 
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 DataSetfrom 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
 
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
 
TwitterFilterSource - Class in org.apache.flink.streaming.connectors.twitter
An extension of TwitterSource by filter parameters.
TwitterFilterSource(String) - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterFilterSource
 
TwitterSink() - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterStreaming.TwitterSink
 
TwitterSource - Class in org.apache.flink.streaming.connectors.twitter
Implementation of SourceFunction specialized to emit tweets from Twitter.
TwitterSource(String) - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterSource
Create TwitterSource for streaming
TwitterSource(String, int) - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterSource
Create TwitterSource to collect finite number of tweets
TwitterStream - Class in org.apache.flink.streaming.examples.twitter
Implements the "TwitterStream" program that computes a most used word occurrence over JSON files in a streaming fashion.
TwitterStream() - Constructor for class org.apache.flink.streaming.examples.twitter.TwitterStream
 
TwitterStream.SelectEnglishAndTokenizeFlatMap - Class in org.apache.flink.streaming.examples.twitter
Makes sentences from English tweets.
TwitterStreamData - Class in org.apache.flink.streaming.examples.twitter.util
 
TwitterStreaming - Class in org.apache.flink.streaming.connectors.twitter
 
TwitterStreaming() - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterStreaming
 
TwitterStreaming.SelectDataFlatMap - Class in org.apache.flink.streaming.connectors.twitter
 
TwitterStreaming.TwitterSink - Class in org.apache.flink.streaming.connectors.twitter
 
TwitterTopology - Class in org.apache.flink.streaming.connectors.twitter
This program demonstrate the use of TwitterSource.
TwitterTopology() - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterTopology
 
TwitterTopology.SelectLanguageFlatMap - Class in org.apache.flink.streaming.connectors.twitter
FlatMapFunction to determine the language of tweets if possible
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
 
TypeCheck - Class in org.apache.flink.api.table.expressions.analysis
Rule that makes sure we call Expression.typeInfo on each Expression at least once.
TypeCheck() - Constructor for class org.apache.flink.api.table.expressions.analysis.TypeCheck
 
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.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
 
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
 
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.
typeInfo() - Method in class org.apache.flink.api.table.expressions.Abs
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Aggregation
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.BinaryArithmetic
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.BinaryComparison
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.BinaryPredicate
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.BitwiseBinaryArithmetic
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.BitwiseNot
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Cast
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Count
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.EqualTo
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Expression
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.IsNotNull
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.IsNull
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Literal
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Naming
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.NopExpression
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Not
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.NotEqualTo
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Plus
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.ResolvedFieldReference
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.Substring
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.UnaryMinus
 
typeInfo() - Method in class org.apache.flink.api.table.expressions.UnresolvedFieldReference
 
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.
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<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.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.ProjectOperator
Deprecated.
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
 
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 pact runtime.
TypeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializer
 
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
 
TypeSerializerSingleton<T> - Class in org.apache.flink.api.common.typeutils.base
 
TypeSerializerSingleton() - Constructor for class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
typeTermForTypeInfo(TypeInformation<?>) - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
typeTermForTypeInfoForCast(TypeInformation<?>) - Method in class org.apache.flink.api.table.codegen.ExpressionCodeGenerator
 
typeToClass(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
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

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.
unary() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
unary() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
unaryBitwiseNot() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
unaryBitwiseNot() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
UnaryExpression - Class in org.apache.flink.api.table.expressions
 
UnaryExpression() - Constructor for class org.apache.flink.api.table.expressions.UnaryExpression
 
UnaryMinus - Class in org.apache.flink.api.table.expressions
 
UnaryMinus(Expression) - Constructor for class org.apache.flink.api.table.expressions.UnaryMinus
 
unaryMinus() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
unaryMinus() - Static method in class org.apache.flink.api.table.parser.ExpressionParser
 
UnaryMinus$ - Class in org.apache.flink.api.table.expressions
 
UnaryMinus$() - Constructor for class org.apache.flink.api.table.expressions.UnaryMinus$
 
unaryNot() - Method in class org.apache.flink.api.table.parser.ExpressionParser$
 
unaryNot() - Static method in class org.apache.flink.api.table.parser.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
 
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.
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
 
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) - 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.
UniformDoubleDistribution - Class in org.apache.flink.api.common.distributions
 
UniformDoubleDistribution() - Constructor for class org.apache.flink.api.common.distributions.UniformDoubleDistribution
 
UniformDoubleDistribution(double, double) - Constructor for class org.apache.flink.api.common.distributions.UniformDoubleDistribution
 
UniformIntegerDistribution - Class in org.apache.flink.api.common.distributions
 
UniformIntegerDistribution() - Constructor for class org.apache.flink.api.common.distributions.UniformIntegerDistribution
 
UniformIntegerDistribution(int, int) - Constructor for class org.apache.flink.api.common.distributions.UniformIntegerDistribution
 
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) - 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) - 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.
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>) - 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.
UnionAll - Class in org.apache.flink.api.table.plan
UnionAll operation, union all elements from left and right.
UnionAll(PlanNode, PlanNode) - Constructor for class org.apache.flink.api.table.plan.UnionAll
 
unionAll(Table) - Method in class org.apache.flink.api.table.Table
Union twoTables.
UnionAll$ - Class in org.apache.flink.api.table.plan
 
UnionAll$() - Constructor for class org.apache.flink.api.table.plan.UnionAll$
 
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.runtime.util
 
UnionIterator() - Constructor for class org.apache.flink.runtime.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.
UnionSemanticProperties() - Constructor for class org.apache.flink.optimizer.dag.BinaryUnionNode.UnionSemanticProperties
 
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.util.EnvironmentInformation
 
UnknownInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
An input channel place holder to be replaced by either a RemoteInputChannel or LocalInputChannel at runtime.
UnknownInputChannel(SingleInputGate, int, ResultPartitionID, ResultPartitionManager, TaskEventDispatcher, ConnectionManager, Tuple2<Integer, Integer>) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel
 
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.
UnrecoverableException - Exception in org.apache.flink.runtime.execution
Exception thrown on unrecoverable failures.
UnrecoverableException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.UnrecoverableException
 
unregisterAggregator(String) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
unregisterAllTaskManagers() - Method in class org.apache.flink.runtime.instance.InstanceManager
Unregisters all currently registered TaskManagers from the InstanceManager.
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.
UnregisterClient$() - Constructor for class org.apache.flink.yarn.YarnMessages.UnregisterClient$
 
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.
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.
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(ActorRef, boolean) - Method in class org.apache.flink.runtime.instance.InstanceManager
Unregisters the TaskManager with the given ActorRef.
unregisterWriter(ResultPartitionWriter) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
 
UnresolvedFieldReference - Class in org.apache.flink.api.table.expressions
 
UnresolvedFieldReference(String) - Constructor for class org.apache.flink.api.table.expressions.UnresolvedFieldReference
 
UnresolvedFieldReference$ - Class in org.apache.flink.api.table.expressions
 
UnresolvedFieldReference$() - Constructor for class org.apache.flink.api.table.expressions.UnresolvedFieldReference$
 
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.
unsetAsContext() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
 
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
 
update(T) - Method in interface org.apache.flink.api.common.state.OperatorState
Deprecated.
Updates the operator state accessible by OperatorState.value() to the given value.
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.LazyDbValueState
 
update(V) - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
 
Update() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.Update
 
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.filesystem.FsValueState
 
update(V) - Method in class org.apache.flink.runtime.state.memory.MemValueState
 
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.
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
 
updateConfig(CommandLineOptions) - Method in class org.apache.flink.client.CliFrontend
Updates the associated configuration with the given command line options
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
 
updateHeavyHitters() - Method in class org.apache.flink.contrib.operatorstatistics.heavyhitters.LossyCounting
 
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
 
UpdatePartitionInfo() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdatePartitionInfo
 
updatePropertiesWithUniqueSets(Set<FieldSet>) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
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
 
UpdateTaskExecutionState(TaskExecutionState) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskExecutionState
 
UpdateTaskExecutionState$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskExecutionState$
 
UpdateTaskMultiplePartitionInfos(ExecutionAttemptID, Seq<Tuple2<IntermediateDataSetID, InputChannelDeploymentDescriptor>>) - 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<Long, Double>, MessageIterator<Double>) - Method in class org.apache.flink.graph.examples.SingleSourceShortestPaths.VertexDistanceUpdater
 
updateVertex(Vertex<K, Tuple2<Long, Double>>, MessageIterator<Tuple2<Long, Double>>) - Method in class org.apache.flink.graph.library.CommunityDetection.VertexLabelUpdater
 
updateVertex(Vertex<K, Long>, MessageIterator<Long>) - 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.PageRank.VertexRankUpdater
 
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.VertexUpdateFunction
This method is invoked once per vertex per superstep.
UpdateVertexLabel() - Constructor for class org.apache.flink.graph.library.LabelPropagation.UpdateVertexLabel
 
uploadJarFiles(JobGraph, ActorGateway, FiniteDuration) - Static method in class org.apache.flink.runtime.client.JobClient
Uploads the specified jar files of the [[JobGraph]] jobGraph to the BlobServer of the JobManager.
uploadRequiredJarFiles(InetSocketAddress) - 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.
upperPart - Variable in class org.apache.flink.util.AbstractID
The upper part of the actual ID
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
 
useKeySelector() - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Returns whether using key selector or not.
usePython3 - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
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_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.AbstractStateBackend
 
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
 
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
 
useSingleActorSystem() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
usesUDF - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
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.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
 
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.
validateAndNormalizeUri(URI) - Static method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Checks and normalizes the checkpoint data URI.
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
 
validateStateId(String) - Static method in class org.apache.flink.contrib.streaming.state.MySqlAdapter
Tries to avoid SQL injection with weird state names.
validateZooKeeperConfig(Properties) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Validate the ZK configuration, checking for required parameters
vals() - Method in class org.apache.flink.hcatalog.scala.HCatInputFormat
 
value() - Method in interface org.apache.flink.api.common.state.OperatorState
Deprecated.
Returns the current value for the state.
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.table.expressions.Literal
 
value() - Method in class org.apache.flink.contrib.streaming.state.LazyDbValueState
 
value() - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
 
value() - Method in class org.apache.flink.runtime.state.filesystem.FsValueState
 
value() - Method in class org.apache.flink.runtime.state.memory.MemValueState
 
value - Variable in class org.apache.flink.storm.util.SplitStreamType
The actual data value.
Value - Interface in org.apache.flink.types
Basic value interface for types that act as serializable values.
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.Order
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.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.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.contrib.operatorstatistics.OperatorStatisticsConfig.CountDistinctAlgorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.contrib.operatorstatistics.OperatorStatisticsConfig.HeavyHitterAlgorithm
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.memory.MemoryType
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.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.accumulators.AccumulatorRegistry.Metric
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.execution.ExecutionState
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.JobManagerMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.RecoveryMode
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.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.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
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.graph.StreamGraph.ResourceStrategy
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.windowing.triggers.TriggerResult
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.
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.Order
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.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.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.contrib.operatorstatistics.OperatorStatisticsConfig.CountDistinctAlgorithm
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.operatorstatistics.OperatorStatisticsConfig.HeavyHitterAlgorithm
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() - 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.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.EdgeDirection
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() - 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.accumulators.AccumulatorRegistry.Metric
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.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.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.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.RecoveryMode
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() - 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.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
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.graph.StreamGraph.ResourceStrategy
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.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.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.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.
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
 
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
Creates a new ValueStateDescriptor with the given name, type, and default value.
ValueStateDescriptor(String, TypeInformation<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and default value.
ValueStateDescriptor(String, TypeSerializer<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name, default value, and the specific serializer.
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
 
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
 
VerifyBoolean - Class in org.apache.flink.api.table.expressions.analysis
Rule that verifies that the result type of an Expression is Boolean.
VerifyBoolean() - Constructor for class org.apache.flink.api.table.expressions.analysis.VerifyBoolean
 
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
 
VerifyNoAggregates - Class in org.apache.flink.api.table.expressions.analysis
Rule that verifies that an expression does not contain aggregate operations.
VerifyNoAggregates() - Constructor for class org.apache.flink.api.table.expressions.analysis.VerifyNoAggregates
 
VerifyNoNestedAggregates - Class in org.apache.flink.api.table.expressions.analysis
Rule that verifies that an expression does not contain aggregate operations as children of aggregate operations.
VerifyNoNestedAggregates() - Constructor for class org.apache.flink.api.table.expressions.analysis.VerifyNoNestedAggregates
 
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
 
VertexDistanceUpdater() - Constructor for class org.apache.flink.graph.examples.IncrementalSSSP.VertexDistanceUpdater
 
VertexDistanceUpdater() - Constructor for class org.apache.flink.graph.examples.SingleSourceShortestPaths.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
 
vertexIDtoBrokerID - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
 
vertexIDtoLoopTimeout - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
 
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.
vertexKey - Variable in class org.apache.flink.graph.GraphCsvReader
 
VertexLabelUpdater(Double) - Constructor for class org.apache.flink.graph.library.CommunityDetection.VertexLabelUpdater
 
VertexRankUpdater(double, long) - Constructor for class org.apache.flink.graph.library.PageRank.VertexRankUpdater
 
vertexReader - Variable in class org.apache.flink.graph.GraphCsvReader
 
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
 
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.
VertexUpdateFunction<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.
VertexUpdateFunction() - Constructor for class org.apache.flink.graph.spargel.VertexUpdateFunction
 
vertexValue - Variable in class org.apache.flink.graph.GraphCsvReader
 
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
 
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
 
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
 
visitClassType(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
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
 
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
 
visitLdcInsn(Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
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.
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
 
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
 
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
 
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
 
waitForAllVerticesToReachFinishingState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
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.
waitForTaskManagersToBeRegisteredAtJobManager(ActorRef) - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
waitTillAllocated() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
 
waitTillAllocated(long) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotAllocationFuture
 
waitUntilFinished() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
For testing: This waits until the job execution has finished.
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.
watermarkTimer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
watermarkTimers - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Current waiting watermark callbacks.
watermarkTimersQueue - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
WC() - Constructor for class org.apache.flink.examples.java.JavaTableExample.WC
 
WC(String, int) - Constructor for class org.apache.flink.examples.java.JavaTableExample.WC
 
WC(String, int) - Constructor for class org.apache.flink.examples.scala.WordCountTable.WC
 
WC$() - Constructor for class org.apache.flink.examples.scala.WordCountTable.WC$
 
WEB_MONITOR_ADDRESS_KEY - Static variable in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
 
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, ActorSystem) - Constructor for class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
 
webServerPort() - Method in class org.apache.flink.yarn.YarnMessages.StartYarnSession
 
WEIGHT_VECTOR() - Method in class org.apache.flink.ml.classification.SVM$
 
WEIGHT_VECTOR() - 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
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
 
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(Expression) - Method in class org.apache.flink.api.table.Table
Filters out elements that don't pass the filter predicate.
where(String) - Method in class org.apache.flink.api.table.Table
Filters out elements that don't pass the filter predicate.
where(FilterFunction<F>) - Method in class org.apache.flink.cep.pattern.Pattern
Specifies a filter condition which has to be fulfilled by an event in order to be matched.
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
 
WhitespaceTokenizer() - Constructor for class org.apache.flink.util.SimpleStringUtils.WhitespaceTokenizer
Creates a new tokenizer with an undefined internal state.
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(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(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 - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
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
 
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
 
WindowBuffer<T,O> - Interface in org.apache.flink.streaming.runtime.operators.windowing.buffers
A WindowBuffer is used by WindowOperator to store the elements of one pane.
windowBuffer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
WindowBufferFactory<T,O,B extends WindowBuffer<T,O>> - Interface in org.apache.flink.streaming.runtime.operators.windowing.buffers
A factory for WindowBuffers.
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
 
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.
WindowJoin - Class in org.apache.flink.streaming.examples.join
Example illustrating join over sliding windows of streams in Flink.
WindowJoin() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoin
 
WindowJoin - Class in org.apache.flink.streaming.scala.examples.join
 
WindowJoin() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
WindowJoin$ - Class in org.apache.flink.streaming.scala.examples.join
 
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.GradeSource - Class in org.apache.flink.streaming.examples.join
Continuously emit tuples with random names and integers (grades).
WindowJoin.MyJoinFunction - Class in org.apache.flink.streaming.examples.join
 
WindowJoin.MySourceMap - Class in org.apache.flink.streaming.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
 
WindowJoin.SalarySource - Class in org.apache.flink.streaming.examples.join
Continuously emit tuples with random names and integers (salaries).
WindowJoinData - Class in org.apache.flink.streaming.examples.join.util
 
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 MergingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Creates a new WindowOperator based on the given policies and user functions.
WindowOperator.Context - Class in org.apache.flink.streaming.runtime.operators.windowing
Context is a utility for handling Trigger invocations.
WindowOperator.Timer<K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
Internal class for keeping track of in-flight timers.
windows - Variable in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator
The windows (panes) that are currently in-flight.
windowSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
For serializing the window in checkpoints.
windowStateDescriptor - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
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
 
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) - Method in class org.apache.flink.api.scala.DataSet
Adds a certain data set as a broadcast set to this operator.
withDefaultApplicationName(String) - Method in class org.apache.flink.client.FlinkYarnSessionCli
Sets the default Yarn Application Name.
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>>, VertexUpdateFunction<K, VV, Message>, MessagingFunction<K, VV, Message, EV>, 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).
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>) - 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>) - 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>) - Method in class org.apache.flink.api.scala.DataSet
 
within(Time) - Method in class org.apache.flink.cep.pattern.Pattern
Defines the maximum time interval for a matching pattern.
WithOperations(Expression) - Constructor for class org.apache.flink.api.scala.table.ImplicitExpressionConversions.WithOperations
 
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) - 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
 
withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - Method in class org.apache.flink.streaming.api.functions.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 - Variable in class org.apache.flink.examples.java.JavaTableExample.WC
 
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() - Method in class org.apache.flink.examples.scala.WordCountTable.WC
 
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
 
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.java8.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files.
WordCount() - Constructor for class org.apache.flink.examples.java8.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.java8.wordcount
Implements the streaming "WordCount" program that computes a simple word occurrences over text files.
WordCount() - Constructor for class org.apache.flink.streaming.examples.java8.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
 
WordCountTable - Class in org.apache.flink.examples.scala
Simple example for demonstrating the use of the Table API for a Word Count.
WordCountTable() - Constructor for class org.apache.flink.examples.scala.WordCountTable
 
WordCountTable$ - Class in org.apache.flink.examples.scala
Simple example for demonstrating the use of the Table API for a Word Count.
WordCountTable$() - Constructor for class org.apache.flink.examples.scala.WordCountTable$
 
WordCountTable.WC - Class in org.apache.flink.examples.scala
 
WordCountTable.WC$ - Class in org.apache.flink.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
 
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
 
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
 
wrappedComparator() - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
wrappedFunction - Variable in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
wrappedFunction - Variable in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
wrappedFunction - Variable in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
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
 
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.
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
 
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(DataOutputView) - Method in class org.apache.flink.api.common.distributions.SimpleDistribution
 
write(DataOutputView) - Method in class org.apache.flink.api.common.distributions.SimpleIntegerDistribution
 
write(DataOutputView) - Method in class org.apache.flink.api.common.distributions.UniformDoubleDistribution
 
write(DataOutputView) - Method in class org.apache.flink.api.common.distributions.UniformIntegerDistribution
 
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(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(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, Schema) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
 
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.configuration.Configuration
 
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(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.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.instance.InstanceConnectionInfo
 
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.operators.util.TaskConfig.DelegatingConfiguration
 
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.FsStateBackend.FsCheckpointStateOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend.FsCheckpointStateOutputStream
 
write(int) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend.MemoryCheckpointOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend.MemoryCheckpointOutputStream
 
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(DataOutputView) - Method in class org.apache.flink.runtime.util.SerializableArrayList
 
write(DataOutputView) - Method in class org.apache.flink.runtime.util.SerializableHashMap
 
write(DataOutputView) - Method in class org.apache.flink.runtime.util.SerializableHashSet
 
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.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.Pair
 
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(DataOutputView) - Method in class org.apache.flink.util.AbstractID
 
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) - 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.
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) - 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.
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.
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
 
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
 
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
 
writeEndOfSuperstep() - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
writeEnum(int) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeEnum(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeEvent(AbstractEvent, int) - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
writeEventToAllChannels(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
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
 
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.
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
 
writeJobManagerAddressToConfig(InetSocketAddress) - Method in class org.apache.flink.client.CliFrontend
Writes the given job manager address to the associated configuration object
writeKeyAndNamespace(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
 
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) - Method in class org.apache.flink.api.table.typeinfo.NullMaskUtils$
 
writeNullMask(int, Row, DataOutputView) - Static method in class org.apache.flink.api.table.typeinfo.NullMaskUtils
 
writeObjectToConfig(Object, Configuration, String) - Static method in class org.apache.flink.util.InstantiationUtil
 
writeOptions - Variable in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
We disable writes to the write-ahead-log here.
writeOptions - Variable in class org.apache.flink.contrib.streaming.state.RocksDBListState
We disable writes to the write-ahead-log here.
writeOptions - Variable in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
We disable writes to the write-ahead-log here.
writeOptions - Variable in class org.apache.flink.contrib.streaming.state.RocksDBValueState
We disable writes to the write-ahead-log here.
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 - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
Writer<T> - Interface in org.apache.flink.streaming.connectors.fs
An implementation of Writer is used in conjunction with a RollingSink 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(OUT) - 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(T) - Method in class org.apache.flink.graph.examples.utils.ExampleUtils.PrintingOutputFormatWithMessage
 
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
 
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
 
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
 
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
 
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.
writeToState(AbstractStateBackend.CheckpointStateOutputView) - Method in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator.Context
 
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(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.PojoComparator
 
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(T, DataOutputView) - Method in class org.apache.flink.api.table.typeinfo.NullAwareComparator
 
writeWithKeyNormalization(Row, DataOutputView) - Method in class org.apache.flink.api.table.typeinfo.RowComparator
 

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$
 

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_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
Prefix for passing custom environment variables to Flink's ApplicationMaster (JobManager).
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_DEPLOY_JOBMANAGER - Static variable in class org.apache.flink.client.CliFrontend
A special host name used to run a job by deploying Flink into a YARN cluster, if this string is specified as the JobManager address
YARN_DYNAMIC_PROPERTIES_SEPARATOR - Static variable in class org.apache.flink.client.CliFrontend
 
YARN_HEAP_CUTOFF_MIN - Static variable in class org.apache.flink.configuration.ConfigConstants
Minimum amount of memory to remove from the heap space as a safety margin.
YARN_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
Percentage of heap space to remove from containers started by YARN.
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_DYNAMIC_PROPERTIES_STRING - Static variable in class org.apache.flink.client.CliFrontend
 
YARN_PROPERTIES_FILE - Static variable in class org.apache.flink.client.CliFrontend
 
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_PROPERTIES_JOBMANAGER_KEY - Static variable in class org.apache.flink.client.CliFrontend
 
YARN_PROPERTIES_PARALLELISM - Static variable in class org.apache.flink.client.CliFrontend
 
YARN_REALLOCATE_FAILED_CONTAINERS - Static variable in class org.apache.flink.configuration.ConfigConstants
Reallocate failed YARN containers.
YARN_TASK_MANAGER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
Similar to the YARN_APPLICATION_MASTER_ENV_PREFIX, this configuration prefix allows setting custom environment variables.
YARN_VCORES - Static variable in class org.apache.flink.configuration.ConfigConstants
The vcores exposed by YYARN.
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$
 
YarnDeploymentException() - Constructor for exception org.apache.flink.yarn.FlinkYarnClientBase.YarnDeploymentException
 
YarnDeploymentException(String) - Constructor for exception org.apache.flink.yarn.FlinkYarnClientBase.YarnDeploymentException
 
YarnDeploymentException(String, Throwable) - Constructor for exception org.apache.flink.yarn.FlinkYarnClientBase.YarnDeploymentException
 
yarnJobManager() - Method in class org.apache.flink.yarn.ApplicationClient
 
YarnJobManager - Class in org.apache.flink.yarn
JobManager actor for execution on Yarn.
YarnJobManager(Configuration, ExecutorService, InstanceManager, Scheduler, BlobLibraryCacheManager, ActorRef, RestartStrategy, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, SavepointStore, FiniteDuration) - Constructor for class org.apache.flink.yarn.YarnJobManager
 
YarnJobManager.AMRMClientAsyncHandler - Class in org.apache.flink.yarn
 
YarnMessage(String, Date) - Constructor for class org.apache.flink.yarn.YarnMessages.YarnMessage
 
YarnMessage$() - Constructor for class org.apache.flink.yarn.YarnMessages.YarnMessage$
 
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.JobManagerStopped$ - Class in org.apache.flink.yarn
 
YarnMessages.LocalGetYarnClusterStatus$ - Class in org.apache.flink.yarn
 
YarnMessages.LocalGetYarnMessage$ - Class in org.apache.flink.yarn
 
YarnMessages.LocalStopAMAfterJob - Class in org.apache.flink.yarn
 
YarnMessages.LocalStopAMAfterJob$ - Class in org.apache.flink.yarn
 
YarnMessages.LocalStopYarnSession - Class in org.apache.flink.yarn
 
YarnMessages.LocalStopYarnSession$ - Class in org.apache.flink.yarn
 
YarnMessages.PollYarnClusterStatus$ - Class in org.apache.flink.yarn
 
YarnMessages.RegisterApplicationClient$ - Class in org.apache.flink.yarn
Registration message sent from the ApplicationClient to the YarnJobManager.
YarnMessages.StartYarnSession - Class in org.apache.flink.yarn
Entry point to start a new YarnSession.
YarnMessages.StartYarnSession$ - Class in org.apache.flink.yarn
 
YarnMessages.StopAMAfterJob - Class in org.apache.flink.yarn
 
YarnMessages.StopAMAfterJob$ - Class in org.apache.flink.yarn
 
YarnMessages.StopYarnSession - Class in org.apache.flink.yarn
 
YarnMessages.StopYarnSession$ - 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.UnregisterClient$ - Class in org.apache.flink.yarn
 
YarnMessages.YarnContainersAllocated - Class in org.apache.flink.yarn
Callback from the async resource manager 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 resource manager client when containers were completed.
YarnMessages.YarnContainersCompleted$ - Class in org.apache.flink.yarn
 
YarnMessages.YarnMessage - Class in org.apache.flink.yarn
 
YarnMessages.YarnMessage$ - Class in org.apache.flink.yarn
 
YarnTaskManager - Class in org.apache.flink.yarn
An extension of the TaskManager that listens for additional YARN related messages.
YarnTaskManager(TaskManagerConfiguration, InstanceConnectionInfo, MemoryManager, IOManager, NetworkEnvironment, int, LeaderRetrievalService) - 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
 

Z

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
ZooKeeper root path (ZNode) for checkpoint counters.
ZOOKEEPER_CHECKPOINTS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper root path (ZNode) for completed checkpoints.
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
ZOOKEEPER_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper root path.
ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper root path (ZNode) for job graphs.
ZOOKEEPER_LATCH_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
ZOOKEEPER_LEADER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
 
ZOOKEEPER_QUORUM_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper servers.
ZOOKEEPER_RECOVERY_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
File system state backend base path for recoverable state handles.
ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
ZooKeeperCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
CheckpointIDCounter instances for JobManagers running in RecoveryMode.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) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
zookeeperCluster() - Method in class org.apache.flink.test.util.ForkableFlinkMiniCluster
 
ZooKeeperCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
ZooKeeperCompletedCheckpointStore(int, ClassLoader, CuratorFramework, String, StateStorageHelper<CompletedCheckpoint>) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
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.
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
 
ZooKeeperStateHandleStore<T extends Serializable> - Class in org.apache.flink.runtime.zookeeper
State handles backed by ZooKeeper.
ZooKeeperStateHandleStore(CuratorFramework, StateStorageHelper) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
ZooKeeperSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
SubmittedJobGraph instances for JobManagers running in RecoveryMode.ZOOKEEPER.
ZooKeeperSubmittedJobGraphStore(CuratorFramework, String, StateStorageHelper<SubmittedJobGraph>) - Constructor for class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Submitted job graph store backed by ZooKeeper
ZooKeeperUtils - Class in org.apache.flink.runtime.util
 
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–2017 The Apache Software Foundation. All rights reserved.