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.InPlaceMutableHashTable
 
abort() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
abort() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
abort() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
abort() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
abort() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
abort() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
abort() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
Aborts the matching process.
abort(TXN) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Abort a transaction.
abort(FlinkKafkaProducer011.KafkaTransactionState) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
 
abortCheckpointOnBarrier(long, Throwable) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
Aborts a checkpoint as the result of receiving possibly some checkpoint barriers, but at least one CancelCheckpointMarker.
abortCheckpointOnBarrier(long, Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
abortDeclined() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
abortError(Throwable) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts the pending checkpoint due to an error.
abortExpired() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts a checkpoint because it expired (took too long).
abortSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts the pending checkpoint because a newer completed checkpoint subsumed it.
abortTransaction() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
 
absoluteTimeMillis() - Method in class org.apache.flink.runtime.util.clock.Clock
 
absoluteTimeMillis() - Method in class org.apache.flink.runtime.util.clock.SystemClock
 
AbstractAsyncCallableWithResources<V> - Class in org.apache.flink.runtime.io.async
This abstract class encapsulates the lifecycle and execution strategy for asynchronous operations that use resources.
AbstractAsyncCallableWithResources() - Constructor for class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
 
AbstractBlobCache - Class in org.apache.flink.runtime.blob
Abstract base class for permanent and transient BLOB files.
AbstractBlobCache(InetSocketAddress, Configuration, BlobView, Logger) - Constructor for class org.apache.flink.runtime.blob.AbstractBlobCache
 
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
 
AbstractCassandraTupleSink<IN> - Class in org.apache.flink.streaming.connectors.cassandra
Abstract sink to write tuple-like values into a Cassandra cluster.
AbstractCassandraTupleSink(String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.AbstractCassandraTupleSink
 
AbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
Base class for checkpoint related REST handler.
AbstractCheckpointHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
 
AbstractCheckpointMessage - Class in org.apache.flink.runtime.messages.checkpoint
The base class of all checkpoint messages.
AbstractCheckpointMessage(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
AbstractCheckpointStats - Class in org.apache.flink.runtime.checkpoint
Base class for checkpoint statistics.
AbstractCloseableRegistry<C extends Closeable,T> - Class in org.apache.flink.util
This is the abstract base class for registries that allow to register instances of Closeable, which are all closed if this registry is closed.
AbstractCloseableRegistry(Map<Closeable, T>) - Constructor for class org.apache.flink.util.AbstractCloseableRegistry
 
AbstractDeserializationSchema<T> - Class in org.apache.flink.api.common.serialization
The deserialization schema describes how to turn the byte messages delivered by certain data sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by Flink.
AbstractDeserializationSchema() - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
 
AbstractDeserializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
Deprecated.
AbstractDeserializationSchema() - Constructor for class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
Deprecated.
 
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
 
AbstractExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
Base class for all AccessExecutionGraph based REST handlers.
AbstractExecutionGraphHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
 
AbstractExecutionGraphRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Base class for request handlers whose response depends on an ExecutionGraph that can be retrieved via "jobid" parameter.
AbstractExecutionGraphRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractExecutionGraphRequestHandler
 
AbstractFetcher<T,KPH> - Class in org.apache.flink.streaming.connectors.kafka.internals
Base class for all fetchers, which implement the connections to Kafka brokers and pull records from Kafka partitions.
AbstractFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, ProcessingTimeService, long, ClassLoader, MetricGroup, boolean) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
 
AbstractFileIOChannel - Class in org.apache.flink.runtime.io.disk.iomanager
 
AbstractFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
Creates a new channel to the path indicated by the given ID.
AbstractHashTableProber<PT,BT> - Class in org.apache.flink.runtime.operators.hash
 
AbstractHashTableProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Constructor for class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
AbstractHeapMergingState<K,N,IN,OUT,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.heap
Base class for MergingState (InternalMergingState) that is stored on the heap.
AbstractHeapMergingState(SD, StateTable<K, N, SV>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapMergingState
Creates a new key/value state for the given hash map of key/value pairs.
AbstractHeapState<K,N,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.heap
Base class for partitioned ListState implementations that are backed by a regular heap hash map.
AbstractHeapState(SD, StateTable<K, N, SV>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapState
Creates a new key/value state for the given hash map of key/value pairs.
AbstractID - Class in org.apache.flink.util
A statistically unique identification number.
AbstractID(byte[]) - Constructor for class org.apache.flink.util.AbstractID
Constructs a new ID with a specific bytes value.
AbstractID(long, long) - Constructor for class org.apache.flink.util.AbstractID
Constructs a new abstract ID.
AbstractID(AbstractID) - Constructor for class org.apache.flink.util.AbstractID
Copy constructor: Creates a new abstract ID from the given one.
AbstractID() - Constructor for class org.apache.flink.util.AbstractID
Constructs a new random ID from a uniform distribution.
AbstractInvokable - Class in org.apache.flink.runtime.jobgraph.tasks
This is the abstract base class for every task that can be executed by a TaskManager.
AbstractInvokable() - Constructor for class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
 
AbstractIterativeTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
The abstract base class for all tasks able to participate in an iteration.
AbstractIterativeTask() - Constructor for class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
AbstractJobVertexRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
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(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractJobVertexRequestHandler
 
AbstractJoinDescriptor - Class in org.apache.flink.optimizer.operators
Defines the possible global properties for a join.
AbstractJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
AbstractJoinDescriptor(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
AbstractJsonRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Base class for most request handlers.
AbstractJsonRequestHandler(Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractJsonRequestHandler
 
AbstractKeyedCEPPatternOperator<IN,KEY,OUT,F extends Function> - Class in org.apache.flink.cep.operator
Abstract CEP pattern operator for a keyed input stream.
AbstractKeyedCEPPatternOperator(TypeSerializer<IN>, boolean, NFACompiler.NFAFactory<IN>, EventComparator<IN>, AfterMatchSkipStrategy, F) - Constructor for class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
AbstractKeyedStateBackend<K> - Class in org.apache.flink.runtime.state
Base implementation of KeyedStateBackend.
AbstractKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig) - Constructor for class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
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
 
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
 
AbstractMesosServices - Class in org.apache.flink.mesos.runtime.clusterframework.services
An abrstact implementation of MesosServices.
AbstractMesosServices(ActorSystem, MesosArtifactServer) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.services.AbstractMesosServices
 
AbstractMetricGroup<A extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
Abstract MetricGroup that contains key functionality for adding metrics and groups.
AbstractMetricGroup(MetricRegistry, String[], A) - Constructor for class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
AbstractMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Abstract request handler that returns a list of all available metrics or the values for a set of metrics.
AbstractMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AbstractMetricsHandler
 
AbstractMultiFSDataInputStream - Class in org.apache.flink.core.fs
Abstract base class for wrappers over multiple FSDataInputStream, which gives a contiguous view on all inner streams and makes them look like a single stream, in which we can read, seek, etc.
AbstractMultiFSDataInputStream() - Constructor for class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
 
AbstractMutableHashTable<T> - Class in org.apache.flink.runtime.operators.hash
 
AbstractMutableHashTable(TypeSerializer<T>, TypeComparator<T>) - Constructor for class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
AbstractNonHaServices - Class in org.apache.flink.runtime.highavailability.nonha
Abstract base class for non high-availability services.
AbstractNonHaServices() - Constructor for class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
AbstractOperatorBackendStateMetaInfoReader(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader
 
AbstractOperatorBackendStateMetaInfoWriter(RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter
 
AbstractOperatorDescriptor - Interface in org.apache.flink.optimizer.operators
The root of all descriptions of an operator to the optimizer.
AbstractOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
The abstract outer join driver implements the logic of an outer join operator at runtime.
AbstractOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
AbstractPagedInputView - Class in org.apache.flink.runtime.memory
The base class for all input views that are backed by multiple memory pages.
AbstractPagedInputView(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
Creates a new view that starts with the given segment.
AbstractPagedInputView(int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
Creates a new view that is initially not bound to a memory segment.
AbstractPagedOutputView - Class in org.apache.flink.runtime.memory
The base class for all output views that are backed by multiple memory pages.
AbstractPagedOutputView(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
Creates a new output view that writes initially to the given initial segment.
AbstractPagedOutputView(int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
AbstractPartialSolutionNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of the partial solution that is input to a bulk iteration.
AbstractPartialSolutionNode(Operator<?>) - Constructor for class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
AbstractPartitionDiscoverer - Class in org.apache.flink.streaming.connectors.kafka.internals
Base class for all partition discoverers.
AbstractPartitionDiscoverer(KafkaTopicsDescriptor, int, int) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.AbstractPartitionDiscoverer
 
AbstractPartitionDiscoverer.ClosedException - Exception in org.apache.flink.streaming.connectors.kafka.internals
Thrown if this discoverer was used to discover partitions after it was closed.
AbstractPartitionDiscoverer.WakeupException - Exception in org.apache.flink.streaming.connectors.kafka.internals
Signaling exception to indicate that an actual Kafka call was interrupted.
AbstractPerWindowStateStore() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
 
AbstractReader - Class in org.apache.flink.runtime.io.network.api.reader
A basic reader implementation, which wraps an input gate and handles events.
AbstractReader(InputGate) - Constructor for class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
AbstractReporter - Class in org.apache.flink.metrics.reporter
Base interface for custom metric reporters.
AbstractReporter() - Constructor for class org.apache.flink.metrics.reporter.AbstractReporter
 
AbstractRestHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler
Super class for netty-based handlers that work with RequestBodys and ResponseBodys.
AbstractRestHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, MessageHeaders<R, P, M>) - Constructor for class org.apache.flink.runtime.rest.handler.AbstractRestHandler
 
AbstractRichFunction - Class in org.apache.flink.api.common.functions
An abstract stub implementation for rich user-defined functions.
AbstractRichFunction() - Constructor for class org.apache.flink.api.common.functions.AbstractRichFunction
 
AbstractRocksDBState<K,N,S extends State,SD extends StateDescriptor<S,V>,V> - Class in org.apache.flink.contrib.streaming.state
Base class for State implementations that store state in a RocksDB database.
AbstractRocksDBState(ColumnFamilyHandle, TypeSerializer<N>, SD, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Creates a new RocksDB backed state.
AbstractRuntimeUDFContext - Class in org.apache.flink.api.common.functions.util
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
AbstractRuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>, Map<String, Future<Path>>, MetricGroup) - Constructor for class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
AbstractServerBase<REQ extends MessageBody,RESP extends MessageBody> - Class in org.apache.flink.queryablestate.network
The base class for every server in the queryable state module.
AbstractServerBase(String, InetAddress, Iterator<Integer>, Integer, Integer) - Constructor for class org.apache.flink.queryablestate.network.AbstractServerBase
Creates the AbstractServerBase.
AbstractServerHandler<REQ extends MessageBody,RESP extends MessageBody> - Class in org.apache.flink.queryablestate.network
The base class of every handler used by an AbstractServerBase.
AbstractServerHandler(AbstractServerBase<REQ, RESP>, MessageSerializer<REQ, RESP>, KvStateRequestStats) - Constructor for class org.apache.flink.queryablestate.network.AbstractServerHandler
Create the handler.
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
An abstract base implementation of the StateBackend interface.
AbstractStateBackend() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend
 
AbstractStreamOperator<OUT> - Class in org.apache.flink.streaming.api.operators
Base class for all stream operators.
AbstractStreamOperator() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
AbstractStreamOperator.CountingOutput - Class in org.apache.flink.streaming.api.operators
Wrapping Output that updates metrics on the number of emitted elements.
AbstractStreamOperator.LatencyGauge - Class in org.apache.flink.streaming.api.operators
The gauge uses a HashMap internally to avoid classloading issues when accessing the values using JMX.
AbstractSubtaskAttemptRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
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(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskAttemptRequestHandler
 
AbstractSubtaskRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
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(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskRequestHandler
 
AbstractTableInputFormat<T> - Class in org.apache.flink.addons.hbase
Abstract InputFormat to read data from HBase tables.
AbstractTableInputFormat() - Constructor for class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
AbstractTestBase - Class in org.apache.flink.test.util
A base class for tests that run test programs in a Flink mini cluster.
AbstractTestBase(Configuration) - Constructor for class org.apache.flink.test.util.AbstractTestBase
 
AbstractUdfOperator<OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
Abstract superclass for all contracts that represent actual operators.
AbstractUdfOperator(UserCodeWrapper<FT>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.AbstractUdfOperator
Creates a new abstract operator with the given name wrapping the given user function.
AbstractUdfStreamOperator<OUT,F extends Function> - Class in org.apache.flink.streaming.api.operators
This is used as the base class for operators that have a user-defined function.
AbstractUdfStreamOperator(F) - Constructor for class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
AbstractYarnClusterDescriptor - Class in org.apache.flink.yarn
The descriptor with deployment information for spawning or resuming a YarnClusterClient.
AbstractYarnClusterDescriptor(Configuration, String) - Constructor for class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
AbstractYarnNonHaServices - Class in org.apache.flink.yarn.highavailability
Abstract base class for the high availability services for Flink YARN applications that support no master fail over.
AbstractYarnNonHaServices(Configuration, Configuration) - Constructor for class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
Creates new YARN high-availability services, configuring the file system and recovery data directory based on the working directory in the given Hadoop configuration.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.Plan
Traverses the job depth first from all data sinks on towards the sources.
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
This method implements the visit of a depth-first graph traversing visitor.
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
Applies the given visitor top down to all nodes, starting at the sinks.
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
accept(T) - Method in interface org.apache.flink.util.ThrowingConsumer
Performs this operation on the given argument.
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
 
acceptOffers(AcceptOffers) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosResourceManager
Accept offers as advised by the launch coordinator.
acceptOffers(AcceptOffers) - Method in interface org.apache.flink.mesos.runtime.clusterframework.MesosResourceManagerActions
Accept the given offers as advised by the launch coordinator.
AcceptOffers - Class in org.apache.flink.mesos.scheduler.messages
Local message sent by the launch coordinator to the scheduler to accept offers.
AcceptOffers(String, Collection<Protos.OfferID>, Collection<Protos.Offer.Operation>) - Constructor for class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
AcceptOffers(String, Collection<Protos.OfferID>, Collection<Protos.Offer.Operation>, Protos.Filters) - Constructor for class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.apache.flink.configuration.WebOptions
The config parameter defining the Access-Control-Allow-Origin header for all responses from the web-frontend.
AccessExecution - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime Execution and {@link ArchivedExecution}.
AccessExecutionGraph - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionGraph and ArchivedExecutionGraph.
AccessExecutionJobVertex - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionJobVertex and ArchivedExecutionJobVertex.
AccessExecutionVertex - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionVertex and ArchivedExecutionVertex.
accessField(Field, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
This method is handling the IllegalAccess exceptions of Field.get()
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.
AccumulatorRegistry - Class in org.apache.flink.runtime.accumulators
Main accumulator registry which encapsulates user-defined accumulators.
AccumulatorRegistry(JobID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
AccumulatorSnapshot - Class in org.apache.flink.runtime.accumulators
This class encapsulates a map of accumulators for a single task.
AccumulatorSnapshot(JobID, ExecutionAttemptID, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
ack(Object) - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
ack(Object) - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
Acknowledge - Class in org.apache.flink.runtime.messages
A generic acknowledgement message.
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
 
acknowledgeCheckpoint(long, CheckpointMetrics) - Method in interface org.apache.flink.runtime.execution.Environment
Confirms that the invokable has successfully completed all steps it needed to to for the checkpoint with the give checkpoint-ID.
acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.execution.Environment
Confirms that the invokable has successfully completed all required steps for the checkpoint with the give checkpoint-ID.
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
AcknowledgeCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
This message is sent from the TaskManager to the JobManager to signal that the checkpoint of an individual task is completed.
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
Acknowledges the given checkpoint.
acknowledgeCheckpoint(long, CheckpointMetrics) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
acknowledgeIDs(long, Set<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, Set<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Acknowledges the session ids.
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, TaskStateSnapshot, CheckpointMetrics) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Acknowledges the task with the given execution attempt id and the given subtask state.
acquireResource() - Method in class org.apache.flink.util.ResourceGuard
Acquired access from one new client for the guarded resource.
acquireResources() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
Open the IO Handle (e.g.
ActionRequestFailureHandler - Interface in org.apache.flink.streaming.connectors.elasticsearch
An implementation of ActionRequestFailureHandler is provided by the user to define how failed ActionRequests should be handled, e.g.
activate(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
activate() - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
activate() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
ACTIVE - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
ACTIVE_STATUS - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
actor() - Method in interface org.apache.flink.runtime.instance.ActorGateway
Returns the underlying actor with which is communicated
actor() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Returns ActorRef of the target actor
ActorGateway - Interface in org.apache.flink.runtime.instance
Interface to abstract the communication with an actor.
ActorGatewayCheckpointResponder - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayCheckpointResponder(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
ActorGatewayKvStateRegistryListener - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to forward key-value state notifications to the job manager.
ActorGatewayKvStateRegistryListener(ActorGateway, InetSocketAddress) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
ActorGatewayPartitionProducerStateChecker - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to trigger the partition state check at the job manager.
ActorGatewayPartitionProducerStateChecker(ActorGateway, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
 
ActorGatewayResultPartitionConsumableNotifier - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to notify the job manager about consumable partitions.
ActorGatewayResultPartitionConsumableNotifier(ExecutionContext, ActorGateway, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayResultPartitionConsumableNotifier
 
ActorGatewayTaskExecutionStateListener - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayTaskExecutionStateListener(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayTaskExecutionStateListener
 
ActorGatewayTaskManagerActions - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayTaskManagerActions(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
actorSystemLoader - Variable in class org.apache.flink.client.program.ClusterClient
The actor system used to communicate with the JobManager.
ActorSystemScheduledExecutorAdapter - Class in org.apache.flink.runtime.concurrent.akka
Adapter to use a ActorSystem as a ScheduledExecutor.
ActorSystemScheduledExecutorAdapter(ActorSystem) - Constructor for class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
ActorTaskManagerGateway - Class in org.apache.flink.runtime.jobmanager.slots
Implementation of the TaskManagerGateway for ActorGateway.
ActorTaskManagerGateway(ActorGateway) - Constructor for class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
actualModVersion() - Method in exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
AdamicAdar<K extends CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.drivers
Driver for AdamicAdar.
AdamicAdar() - Constructor for class org.apache.flink.graph.drivers.AdamicAdar
 
AdamicAdar<K extends CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.similarity
http://social.cs.uiuc.edu/class/cs591kgk/friendsadamic.pdf
AdamicAdar() - Constructor for class org.apache.flink.graph.library.similarity.AdamicAdar
 
AdamicAdar.Result<T> - Class in org.apache.flink.graph.library.similarity
A result for the Adamic-Adar algorithm.
AdaptiveSpanningRecordDeserializer<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
 
AdaptiveSpanningRecordDeserializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
add(V) - Method in interface org.apache.flink.api.common.accumulators.Accumulator
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(long) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(int) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
Consider using DoubleCounter.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
Consider using DoubleMaximum.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
Consider using DoubleMinimum.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.Histogram
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntCounter
Consider using IntCounter.add(int) instead for primitive int values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
Consider using IntMaximum.add(int) instead for primitive integer values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
Consider using IntMinimum.add(int) instead for primitive integer values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
add(T) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
Consider using LongCounter.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
Consider using LongMaximum.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
Consider using LongMinimum.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
add(T) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
add(T, TypeSerializer<T>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
add(IN, ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Adds the given input value to the given accumulator, returning the new accumulator value.
add(IN, ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
add(IN) - Method in interface org.apache.flink.api.common.state.AppendingState
Updates the operator state accessible by AppendingState.get() by adding the given value to the list of values.
add(double, double) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding a value and a correction term.
add(double) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding a value without a correction term.
add(CompensatedSum) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding two sums, and updating the correction term for reducing numeric errors.
add() - Method in class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.builder.Tuple15Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class org.apache.flink.api.java.tuple.builder.Tuple16Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class org.apache.flink.api.java.tuple.builder.Tuple17Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class org.apache.flink.api.java.tuple.builder.Tuple18Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
add(T0) - Method in class org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class org.apache.flink.api.java.tuple.builder.Tuple20Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class org.apache.flink.api.java.tuple.builder.Tuple21Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class org.apache.flink.api.java.tuple.builder.Tuple22Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class org.apache.flink.api.java.tuple.builder.Tuple23Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Method in class org.apache.flink.api.java.tuple.builder.Tuple24Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Method in class org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
add(T0, T1) - Method in class org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
add(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
add(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
add(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
add(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
add(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
add(Utils.ChecksumHashCode) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
add(String) - Method in class org.apache.flink.api.java.utils.RequiredParameters
Add a parameter based on its name.
add(Option) - Method in class org.apache.flink.api.java.utils.RequiredParameters
Add a parameter encapsulated in an Option object.
add(T) - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
 
add(T) - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
Deprecated.
 
add(V) - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
 
add(V) - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
 
add(KMeans.Point) - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
 
add(Integer) - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
Increases the result vector component at the specified position by 1.
add(ChecksumHashCode.Checksum) - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
add(ByteValue) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
 
add(CharValue) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
 
add(DoubleValue) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
 
add(FloatValue) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
 
add(IntValue) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
add(LongValue) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
add(NullValue) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
add(ShortValue) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
 
add(StringValue) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
add(T) - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
Appends the value to this array if and only if the array capacity would not be exceeded.
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Between
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Equals
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.In
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.IsNull
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.LessThan
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.LessThanEquals
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Not
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.NullSafeEquals
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Or
 
add(SearchArgument.Builder) - Method in class org.apache.flink.orc.OrcRowInputFormat.Predicate
 
add(int, D) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given DataSet to this cache for the given ID.
add(int, U) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given UnsortedGrouping to this cache for the given ID.
add(int, S) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given SortedGrouping to this cache for the given ID.
add(Object) - Method in class org.apache.flink.queryablestate.client.state.ImmutableAggregatingState
 
add(Object) - Method in class org.apache.flink.queryablestate.client.state.ImmutableFoldingState
Deprecated.
 
add(V) - Method in class org.apache.flink.queryablestate.client.state.ImmutableListState
 
add(V) - Method in class org.apache.flink.queryablestate.client.state.ImmutableReducingState
 
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
Adds the given buffer.
add(IN) - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
add(T) - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
 
add(V) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
add(V) - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
add(Task) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Add the given task to the task slot.
add(T) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
add(int) - Method in class org.apache.flink.runtime.util.IntArrayList
 
add(long) - Method in class org.apache.flink.runtime.util.LongArrayList
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
 
add(ActionRequest...) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.RequestIndexer
Add multiple ActionRequest to the indexer to prepare for sending requests to Elasticsearch.
add(ActionRequest...) - Method in interface org.apache.flink.streaming.connectors.elasticsearch2.RequestIndexer
Deprecated.
 
add(E) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Adds the element to the queue, or fails with an exception, if the queue is closed.
add(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
Adds a buffer or event to the sequence of spilled buffers and events.
add(int, V) - Method in class org.apache.flink.types.ListValue
 
add(V) - Method in class org.apache.flink.types.ListValue
 
add(Iterator<T>) - Method in class org.apache.flink.util.UnionIterator
 
addAccumulator(String, Accumulator<V, A>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Add this accumulator.
addAccumulator(String, Accumulator<V, A>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
addAccumulator(String, Accumulator<V, A>) - Method in class org.apache.flink.graph.AnalyticHelper
Adds an accumulator by prepending the given name with a random string.
addAll(AggregatorRegistry) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
addAll(Configuration) - Method in class org.apache.flink.configuration.Configuration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.Configuration
Adds all entries from the given configuration into this configuration.
addAll(Configuration) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAll(Configuration) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(ValueArray<ByteValue>) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArray
 
addAll(ValueArray<CharValue>) - Method in class org.apache.flink.graph.types.valuearray.CharValueArray
 
addAll(ValueArray<DoubleValue>) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArray
 
addAll(ValueArray<FloatValue>) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArray
 
addAll(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
addAll(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
addAll(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
addAll(ValueArray<ShortValue>) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArray
 
addAll(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
addAll(ValueArray<T>) - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
Appends all of the values in the specified array to the end of this array.
addAll(Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
 
addAll(int, Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
 
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.Configuration
Adds all entries in this Configuration to the given Properties.
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAndLock(String, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Creates a state handle, stores it in ZooKeeper and locks it.
addAppConfigurationEntry(String, AppConfigurationEntry...) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
Add entries for the given application name.
addArtificialDamCost(EstimateProvider, long, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addArtificialDamCost(EstimateProvider, long, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addAvroGenericDataArrayRegistration(LinkedHashMap<String, KryoRegistration>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
Registers a special Serializer for GenericData.Array.
addAvroGenericDataArrayRegistration(LinkedHashMap<String, KryoRegistration>) - Method in class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils
 
addAvroSerializersIfRequired(ExecutionConfig, Class<?>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
Loads the utility class from flink-avro and adds Avro-specific serializers.
addAvroSerializersIfRequired(ExecutionConfig, Class<?>) - Method in class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils
 
addBlob(PermanentBlobKey) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Adds the BLOB referenced by the key to the JobGraph's dependencies.
addBlockNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addBlockNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addBroadcastConnection(String, DagConnection) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Adds the broadcast connection identified by the given name to this node.
addBroadcastCost(EstimateProvider, int, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addBroadcastCost(EstimateProvider, int, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addBroadcastInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addBroadcastSet(String, DataSet<?>) - Method in class org.apache.flink.graph.pregel.VertexCentricConfiguration
Adds a data set as a broadcast set to the compute function.
addBroadcastSetForApplyFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the apply function.
addBroadcastSetForGatherFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the gather function.
addBroadcastSetForGatherFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Adds a data set as a broadcast set to the gather function.
addBroadcastSetForScatterFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Adds a data set as a broadcast set to the scatter function.
addBroadcastSetForSumFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the sum function.
addBufferListener(BufferListener) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Adds a buffer availability listener to the buffer provider.
addCachedHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addCachedHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
Calculates the costs for the cached variant of the hybrid hash join.
addChainedTask(Class<? extends ChainedDriver>, TaskConfig, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addCheckpoint(CompletedCheckpoint) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Adds a CompletedCheckpoint instance to the list of completed checkpoints.
addCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
addCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Synchronously writes the new checkpoints to ZooKeeper and asynchronously removes older ones.
addChoices(String...) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
Add additional choices.
addClass(Class<?>) - Method in class org.apache.flink.runtime.util.JarFileCreator
Adds a Class object to the set of classes which shall eventually be included in the jar file.
addCloseableInternal(Closeable, T) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Adds a mapping to the registry map, respecting locking.
addClosedBranch(OptimizerNode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
addClosedBranches(Set<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
addColumn(String, String, Class<?>) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
Adds a column defined by family, qualifier, and type to the table schema.
addComparatorField(int, TypeComparator<?>) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
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.
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<?>, 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.
addDefaultResource(String) - Static method in class org.apache.hadoop.conf.Configuration
Add a default resource.
addDeprecation(String, String[], String) - Static method in class org.apache.hadoop.conf.Configuration
addDeprecation(String, String, String) - Static method in class org.apache.hadoop.conf.Configuration
Adds the deprecated key to the global deprecation map.
addDeprecation(String, String[]) - Static method in class org.apache.hadoop.conf.Configuration
addDeprecation(String, String) - Static method in class org.apache.hadoop.conf.Configuration
Adds the deprecated key to the global deprecation map when no custom message is provided.
addDeprecations(Configuration.DeprecationDelta[]) - Static method in class org.apache.hadoop.conf.Configuration
Adds a set of deprecated keys to the global deprecations.
addDimension(long, boolean) - Method in class org.apache.flink.graph.generator.GridGraph
Required configuration for each dimension of the graph.
addDiscoveredPartitions(List<KafkaTopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Adds a list of newly discovered partitions to the fetcher for consuming.
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(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.
addFeedbackEdge(StreamTransformation<F>) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Adds a feedback edge.
addFeedbackEdge(StreamTransformation<T>) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
Adds a feedback edge.
addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addField(Value) - Method in class org.apache.flink.types.Record
 
addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addFile(File, String) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
Adds a file to the artifact server.
addFileInputCost(long, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addFileInputCost(long, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addForwardedField(int, int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
Adds, to the existing information, a field that is forwarded directly from the source record(s) in the first input to the destination record(s).
addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
Adds, to the existing information, a field that is forwarded directly from the source record(s) to the destination record(s).
addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
addGeneralOptions(Options) - Method in interface org.apache.flink.client.cli.CustomCommandLine
Adds custom options to the existing general options.
addGeneralOptions(Options) - Method in class org.apache.flink.client.cli.DefaultCLI
 
addGeneralOptions(Options) - Method in class org.apache.flink.client.cli.Flip6DefaultCLI
 
addGeneralOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
addGeneralOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
addGlobalProperties(RequestedGlobalProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
addGroup(int) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
addGroup(String) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
addGroup(int) - Method in interface org.apache.flink.metrics.MetricGroup
Creates a new MetricGroup and adds it to this groups sub-groups.
addGroup(String) - Method in interface org.apache.flink.metrics.MetricGroup
Creates a new MetricGroup and adds it to this groups sub-groups.
addGroup(int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
addGroup(int) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
addHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
 
addHashPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addHashPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addHeuristicCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the given heuristic CPU cost to the current heuristic CPU cost for this Costs object.
addHeuristicDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the heuristic costs for disk to the current heuristic disk costs for this Costs object.
addHeuristicNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the heuristic costs for network to the current heuristic network costs for this Costs object.
addHiddenChoices(String...) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
Add additional hidden choices.
addHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addId(UId) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
Adds an ID to be stored with the current checkpoint.
addIfOpen(E) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Tries to add an element to the queue, if the queue is still open.
addIgnore(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addIgnore(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addInEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInput(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInputs(List<? extends Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
addInterestingProperties(InterestingProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
addIOMetrics(AccessExecution, MetricFetcher, String, String) - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
Adds the IO metrics for the given attempt to this object.
addIterationAggregator(String, Aggregator<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addIterationAggregators(Collection<AggregatorWithName<?>>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addJar(Path) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Adds the path of a JAR file required to run the job on a task manager.
addJob(JobGraph) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
addJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Add a job to be monitored to retrieve the job leader id.
addJob(JobID, String) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Add the given job to be monitored.
addLibFolderToShipFiles(Collection<File>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
addList(List<T>) - Method in class org.apache.flink.util.UnionIterator
 
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
 
AddLongValue() - Constructor for class org.apache.flink.graph.utils.GraphUtils.AddLongValue
 
addMasterHook(MasterTriggerRestoreHook<?>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Adds the given master hook to the checkpoint coordinator.
addMasterState(MasterState) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Adds a master state (state generated on the checkpoint coordinator) to the pending checkpoint.
addMetric(DMetric) - Method in class org.apache.flink.metrics.datadog.DSeries
 
addMetric(String, Metric) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Adds the given metric to the group and registers it at the registry, if the group is not yet closed, and if no metric with the same name has been registered before.
addMonths(long, int) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
Adds a given number of months to a timestamp, represented as the number of milliseconds since the epoch.
addMonths(int, int) - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
Adds a given number of months to a date, represented as the number of days since the epoch.
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
 
addOperator(String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
addOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
addOperator(StreamTransformation<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds an operator to the list of operators that should be executed when calling StreamExecutionEnvironment.execute().
addOperator(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addOutEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
addOutgoingChannel(Channel) - Method in class org.apache.flink.optimizer.plan.PlanNode
Adds a channel to a successor node to this node.
addOutgoingConnection(DagConnection) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
addOutgoingConnection(DagConnection) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Adds a new outgoing connection to this node.
addOutputSelector(Integer, OutputSelector<T>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addOutputSelector(OutputSelector<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
addOutputShipStrategy(ShipStrategyType) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addPackage(String) - Method in class org.apache.flink.runtime.util.JarFileCreator
Manually specify the package of the dependencies.
addPackages(String[]) - Method in class org.apache.flink.runtime.util.JarFileCreator
Manually specify the packages of the dependencies.
addParameter(Parameter<?>) - Method in class org.apache.flink.graph.drivers.parameter.ParameterizedBase
Adds a parameter to the list.
addPath(Path, Path) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
Adds a path to the artifact server.
addPredicate(OrcRowInputFormat.Predicate) - Method in class org.apache.flink.orc.OrcRowInputFormat
Adds a filter predicate to reduce the number of rows to be returned by the input format.
addProceed(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addRandomPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addRandomPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addRange(long, long) - Method in class org.apache.flink.graph.generator.CirculantGraph
Required configuration for each range of offsets in the graph.
addRangePartitionCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addRangePartitionCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addReadFields(int, FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
Adds, to the existing information, field(s) that are read in the source record(s) from the first input.
addReadFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
Adds, to the existing information, field(s) that are read in the source record(s).
addRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Starts serializing and copying the given record to the target buffer (if available).
addRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
Serializes the complete record to an intermediate data serialization buffer and starts copying it to the target buffer (if available).
addRecord(T) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
addRequest(R) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
 
addResource(String) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(URL) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(Path) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(InputStream) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(InputStream, String) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
addResource(Configuration) - Method in class org.apache.hadoop.conf.Configuration
Add a configuration resource.
ADDRESS - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the network address to connect to for communication with the job manager.
ADDRESS - Static variable in class org.apache.flink.configuration.WebOptions
Config parameter defining the runtime monitor web-frontend server address.
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.taskmanager.TaskManagerLocation
Returns the network address the instance's task manager binds its sockets to.
ADDRESS_OPTION - Static variable in class org.apache.flink.client.cli.CliFrontendParser
 
addressLimit - Variable in class org.apache.flink.core.memory.MemorySegment
The address one byte after the last addressable byte, i.e.
addressString() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the IP address where the TaskManager operates.
addRunOptions(Options) - Method in interface org.apache.flink.client.cli.CustomCommandLine
Adds custom options to the existing run options.
addRunOptions(Options) - Method in class org.apache.flink.client.cli.DefaultCLI
 
addRunOptions(Options) - Method in class org.apache.flink.client.cli.Flip6DefaultCLI
 
addRunOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
addRunOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
addSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addSemanticPropertiesHints() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, JobVertexID) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, CoLocationConstraint) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
addShipFiles(List<File>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
Adds the given files to the list of files to ship.
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(DataStream<IN>) - Static method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Writes a DataStream into a Cassandra database.
addSink(DataStream<IN>) - Static method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Writes a DataStream into a Cassandra database.
addSource(SourceFunction<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds a Data Source to the streaming topology.
addSource(SourceFunction<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Ads a data source with a custom type information thus opening a DataStream.
addSource(SourceFunction<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Ads a data source with a custom type information thus opening a DataStream.
addSource(SourceFunction<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Ads a data source with a custom type information thus opening a DataStream.
addSource(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
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(StateTransitionAction, State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addStreamedNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addStreamedNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addTake(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addTake(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addTask(JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
addTask(Task) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Add the given task to the slot identified by the task's allocation id.
addTaskForJob(JobID, String, JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
addToDefaults(String, String) - Method in class org.apache.flink.api.java.utils.ParameterTool
 
addToEnvironment(Map<String, String>, String, String) - Static method in class org.apache.flink.yarn.Utils
Copied method from org.apache.hadoop.yarn.util.Apps.
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(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.
addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Adds a new virtual node that is used to connect a downstream vertex to an input with a certain partitioning.
addVirtualSelectNode(Integer, Integer, List<String>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with the selected names.
addVirtualSideOutputNode(Integer, Integer, OutputTag) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with the selected side-output OutputTag.
addWindow(W, MergingWindowSet.MergeFunction<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Adds a new Window to the set of in-flight windows.
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.
advanceWatermark(long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
advanceWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManager
 
AfterMatchSkipStrategy - Class in org.apache.flink.cep.nfa
Indicate the skip strategy after a match process.
afterMatchSkipStrategy - Variable in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
AfterMatchSkipStrategy.SkipStrategy - Enum in org.apache.flink.cep.nfa
Skip Strategy Enum.
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(Aggregations, int) - Method in class org.apache.flink.api.java.DataSet
Applies an Aggregate transformation on a non-grouped Tuple DataSet.
aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies an Aggregate transformation on a grouped Tuple DataSet.
aggregate(T) - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
Add a value to the current aggregation.
aggregate(Boolean) - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
aggregate(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
Add a value to the current aggregation.
aggregate(Object) - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
aggregate(String) - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
aggregate(Tuple) - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
aggregate(VT) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given AggregateFunction to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given AggregateFunction to each window.
aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
 
aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
AggregateApplyAllWindowFunction(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
 
AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
AggregateApplyWindowFunction(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
 
AggregateFunction<IN,ACC,OUT> - Interface in org.apache.flink.api.common.functions
The AggregateFunction is a flexible aggregation function, characterized by the following features: The aggregates may use different types for input values, intermediate aggregates, and result type, to support a wide range of aggregation types. Support for distributive aggregations: Different intermediate aggregates can be merged together, to allow for pre-aggregation/final-aggregation optimizations.
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.
aggregateUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Merges all accumulator results from the tasks previously executed in the Executions.
AggregatingJobsMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns, aggregated across all jobs, a list of all available metrics or the values for a set of metrics.
AggregatingJobsMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingJobsMetricsHandler
 
AggregatingState<IN,OUT> - Interface in org.apache.flink.api.common.state
State interface for aggregating state, based on an AggregateFunction.
AggregatingStateDescriptor<IN,ACC,OUT> - Class in org.apache.flink.api.common.state
A StateDescriptor for AggregatingState.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, Class<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new state descriptor with the given name, function, and type.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeInformation<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new ReducingStateDescriptor with the given name and default value.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeSerializer<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new ValueStateDescriptor with the given name and default value.
AggregatingSubtasksMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns, aggregated across all subtasks, a list of all available metrics or the values for a set of metrics.
AggregatingSubtasksMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingSubtasksMetricsHandler
 
AggregatingTaskManagersMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns, aggregated across all task managers, a list of all available metrics or the values for a set of metrics.
AggregatingTaskManagersMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingTaskManagersMetricsHandler
 
AggregationFunction<T> - Class in org.apache.flink.api.java.aggregation
 
AggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.AggregationFunction
 
AggregationFunction<T> - Class in org.apache.flink.streaming.api.functions.aggregation
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
 
AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
Aggregation types that can be used on a windowed stream or keyed stream.
AggregationFunctionFactory - Interface in org.apache.flink.api.java.aggregation
Interface of factory for creating AggregationFunction.
Aggregations - Enum in org.apache.flink.api.java.aggregation
Shortcuts for Aggregation factories.
Aggregator<T extends Value> - Interface in org.apache.flink.api.common.aggregators
Aggregators are a means of aggregating values across parallel instances of a function.
Aggregator<T,R> - Interface in org.apache.flink.api.java.summarize.aggregation
Generic interface for aggregation.
AGGREGATOR_NAME - Static variable in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
AggregatorRegistry - Class in org.apache.flink.api.common.aggregators
A registry for iteration Aggregators.
AggregatorRegistry() - Constructor for class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
AggregatorWithName<T extends Value> - Class in org.apache.flink.api.common.aggregators
Simple utility class holding an Aggregator with the name it is registered under.
AggregatorWithName(String, Aggregator<T>) - Constructor for class org.apache.flink.api.common.aggregators.AggregatorWithName
Creates a new instance for the given aggregator and name.
AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_FRAMESIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_JVM_EXIT_ON_FATAL_ERROR - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_STARTUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
AKKA_TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_WATCH_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_WATCH_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
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
 
AkkaJobManagerGateway - Class in org.apache.flink.runtime.akka
Implementation of the JobManagerGateway for old JobManager code based on Akka actors and the ActorGateway.
AkkaJobManagerGateway(ActorGateway) - Constructor for class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
AkkaJobManagerRetriever - Class in org.apache.flink.runtime.webmonitor.retriever.impl
LeaderGatewayRetriever implementation for Akka based JobManagers.
AkkaJobManagerRetriever(ActorSystem, Time, int, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaJobManagerRetriever
 
AkkaOptions - Class in org.apache.flink.configuration
Akka configuration options.
AkkaOptions() - Constructor for class org.apache.flink.configuration.AkkaOptions
 
AkkaQueryServiceGateway - Class in org.apache.flink.runtime.webmonitor.retriever.impl
MetricQueryServiceGateway implementation for Akka based MetricQueryService.
AkkaQueryServiceGateway(ActorRef) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
 
AkkaQueryServiceRetriever - Class in org.apache.flink.runtime.webmonitor.retriever.impl
MetricQueryServiceRetriever implementation for Akka based MetricQueryService.
AkkaQueryServiceRetriever(ActorSystem, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceRetriever
 
AkkaRpcException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
Base class for Akka RPC related exceptions.
AkkaRpcException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcService - Class in org.apache.flink.runtime.rpc.akka
Akka based RpcService implementation.
AkkaRpcService(ActorSystem, Time) - Constructor for class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
AkkaRpcServiceUtils - Class in org.apache.flink.runtime.rpc.akka
These RPC utilities contain helper methods around RPC use, such as starting an RPC service, or constructing RPC addresses.
AkkaRpcServiceUtils.AkkaProtocol - Enum in org.apache.flink.runtime.rpc.akka
 
AkkaUnknownMessageException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
Exception which indicates that the AkkaRpcActor has received an unknown message type.
AkkaUnknownMessageException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AkkaUnknownMessageException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AkkaUnknownMessageException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AlignmentLimitExceededException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because too many bytes were buffered in the alignment phase.
AlignmentLimitExceededException(long) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.AlignmentLimitExceededException
 
AllFieldsForwardedProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
AllGroupCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators
Non-chained driver for the partial group reduce operator that acts like a combiner with a custom output type OUT.
AllGroupCombineDriver() - Constructor for class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
AllGroupCombineProperties - Class in org.apache.flink.optimizer.operators
 
AllGroupCombineProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupCombineProperties
 
AllGroupReduceDriver<IT,OT> - Class in org.apache.flink.runtime.operators
GroupReduceDriver task which is executed by a Task Manager.
AllGroupReduceDriver() - Constructor for class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
AllGroupReduceProperties - Class in org.apache.flink.optimizer.operators
 
AllGroupReduceProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupReduceProperties
 
AllGroupWithPartialPreGroupProperties - Class in org.apache.flink.optimizer.operators
 
AllGroupWithPartialPreGroupProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
 
allocate(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Allocate the task slot for the given job and allocation id.
allocateAndAssignSlotForExecution(SlotProvider, boolean, LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.Execution
Allocates and assigns a slot obtained from the slot provider to the execution.
AllocatedSlot - Class in org.apache.flink.runtime.jobmanager.slots
The AllocatedSlot represents a slot that the JobManager allocated from a TaskManager.
AllocatedSlot(AllocationID, JobID, TaskManagerLocation, int, ResourceProfile, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
 
allocatePages(Object, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
Allocates a set of memory segments from this memory manager.
allocatePages(Object, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
Allocates a set of memory segments from this memory manager.
allocateResource(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Allocates a resource according to the resource profile.
allocateResource(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
Requests to allocate a resource with the given ResourceProfile.
allocateResourcesForAll(SlotProvider, boolean, LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Acquires a slot for all the execution vertices of this ExecutionJobVertex.
allocateSegments(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
attempts to allocate specified number of segments and should only be used by compaction partition fails silently if not enough segments are available since next compaction could still succeed
allocateSharedSlot(JobID, SlotSharingGroupAssignment) - Method in class org.apache.flink.runtime.instance.Instance
Allocates a shared slot on this TaskManager instance.
allocateSimpleSlot(JobID) - Method in class org.apache.flink.runtime.instance.Instance
Allocates a simple slot on this TaskManager instance.
allocateSlot(ScheduledUnit, ResourceProfile, Iterable<TaskManagerLocation>, Time) - Method in class org.apache.flink.runtime.instance.SlotPool
 
allocateSlot(ScheduledUnit, ResourceProfile, Iterable<TaskManagerLocation>, Time) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
allocateSlot(ScheduledUnit, boolean, Collection<TaskManagerLocation>) - Method in interface org.apache.flink.runtime.instance.SlotProvider
Allocating slot with specific requirement.
allocateSlot(ScheduledUnit, boolean, Collection<TaskManagerLocation>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
allocateSlot(int, JobID, AllocationID, Time) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Allocate the slot with the given index for the given job and allocation id.
allocateUnpooledSegment(int, Object) - Method in class org.apache.flink.core.memory.HeapMemorySegment.HeapMemorySegmentFactory
Allocates some unpooled memory and creates a new memory segment that represents that memory.
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.
allocationFuture - Variable in class org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
AllocationID - Class in org.apache.flink.runtime.clusterframework.types
Unique identifier for a slot allocated by a JobManager from a TaskManager.
AllocationID() - Constructor for class org.apache.flink.runtime.clusterframework.types.AllocationID
Constructs a new random AllocationID.
AllocationID(long, long) - Constructor for class org.apache.flink.runtime.clusterframework.types.AllocationID
Constructs a new AllocationID with the given parts.
allOutputs - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
allowCombinations() - Method in class org.apache.flink.cep.pattern.Pattern
Applicable only to Quantifier.looping(ConsumingStrategy) and Quantifier.times(ConsumingStrategy) patterns, this option allows more flexibility to the matching events.
allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Sets the time by which elements are allowed to be late.
allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Sets the time by which elements are allowed to be late.
allowedLateness - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
The allowed lateness for elements.
allowLazyDeployment() - Method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
Returns whether we are allowed to deploy consumers lazily.
allowNonRestoredState() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
Returns whether non restored state is allowed if the savepoint contains state that cannot be mapped back to the job.
AllReduceDriver<T> - Class in org.apache.flink.runtime.operators
Reduce task which is executed by a Task Manager.
AllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.AllReduceDriver
 
AllReduceProperties - Class in org.apache.flink.optimizer.operators
 
AllReduceProperties() - Constructor for class org.apache.flink.optimizer.operators.AllReduceProperties
 
allStartedWorkers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets an iterable for all currently started TaskManagers.
AllWindowedStream<T,W extends Window> - Class in org.apache.flink.streaming.api.datastream
A AllWindowedStream represents a data stream where the stream of elements is split into windows based on a WindowAssigner.
AllWindowedStream(DataStream<T>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.AllWindowedStream
 
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.
AllWorkersDoneEvent - Class in org.apache.flink.runtime.iterative.event
Event sent by the IterationSynchronizationSinkTask to each IterationHead signaling to start a new superstep.
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
 
alt(String) - Method in class org.apache.flink.api.java.utils.Option
Define an alternative / short name of the parameter.
ALWAYS_PARENT_FIRST_LOADER - Static variable in class org.apache.flink.configuration.CoreOptions
 
AnalyticHelper<T> - Class in org.apache.flink.graph
A GraphAnalytic computes over a DataSet and returns the results via Flink accumulators.
AnalyticHelper() - Constructor for class org.apache.flink.graph.AnalyticHelper
 
analyze() - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
analyze() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
analyzeDualInputUdf(TwoInputUdfOperator<?, ?, ?, ?>, Class<?>, String, Function, Keys<?>, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
 
analyzePojo(Class<OUT>, ArrayList<Type>, ParameterizedType, TypeInformation<IN1>, TypeInformation<IN2>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
analyzeSingleInputUdf(SingleInputUdfOperator<?, ?, ?>, Class<?>, String, Function, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
 
and(Aggregations, int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
and(Aggregations, int) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator
 
AndCondition<T> - Class in org.apache.flink.cep.pattern.conditions
A condition which combines two conditions with a logical AND and returns true if both are true.
AndCondition(IterativeCondition<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.pattern.conditions.AndCondition
 
AndFilterFunction<T> - Class in org.apache.flink.cep.pattern
Deprecated.
This is only used when migrating from an older Flink version. Use the AndCondition instead.
AndFilterFunction(FilterFunction<T>, FilterFunction<T>) - Constructor for class org.apache.flink.cep.pattern.AndFilterFunction
Deprecated.
 
andMax(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
andMin(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
andSum(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
AnnotationVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
AntiJoinVisits() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.AntiJoinVisits
 
API_KEY - Static variable in class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
APP_MASTER_RPC_ADDRESS - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
The hostname or address where the application master RPC system is listening.
APP_MASTER_RPC_PORT - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
The port where the application master RPC system is listening.
append(char) - Method in class org.apache.flink.types.StringValue
 
append(CharSequence) - Method in class org.apache.flink.types.StringValue
 
append(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
 
append(StringValue) - Method in class org.apache.flink.types.StringValue
 
append(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
 
AppendingState<IN,OUT> - Interface in org.apache.flink.api.common.state
Base interface for partitioned state that supports adding elements and inspecting the current state.
appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
appendKeyRemover(Operator<Tuple2<K, T>>, Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
appendOrdering(Integer, Class<? extends Comparable<?>>, Order) - Method in class org.apache.flink.api.common.operators.Ordering
Extends this ordering by appending an additional order requirement.
appendRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
Inserts the given object into the current buffer.
APPLICATION_ATTEMPTS - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
Set the number of retries for failed YARN ApplicationMasters/JobManagers in high availability mode.
APPLICATION_MASTER_PORT - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
The config parameter defining the Akka actor system port for the ApplicationMaster and JobManager.
APPLICATION_TAGS - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
A comma-separated list of strings to use as YARN application tags.
ApplicationStatus - Enum in org.apache.flink.runtime.clusterframework
The status of an application.
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(S, T) - Method in interface org.apache.flink.runtime.state.StateTransformationFunction
Binary function that applies a given value to the given old state to compute the new state.
apply(I) - Method in interface org.apache.flink.runtime.util.EvictingBoundedList.Function
Transforms the value.
apply(AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
apply(AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
apply(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Completes the co-group operation with the user function that is executed for windowed groups.
apply(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Completes the co-group operation with the user function that is executed for windowed groups.
apply(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
apply(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
apply(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
apply(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
apply(WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
apply(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
 
apply(W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.AllWindowFunction
Evaluates the window and outputs none or several elements.
apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
Deprecated.
 
apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
 
apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
 
apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.WindowFunction
Evaluates the window and outputs none or several elements.
apply(TimeWindow, Iterable<Integer>, Collector<Double[]>) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.PartialModelBuilder
 
apply(Statement, Description) - Method in class org.apache.flink.testutils.junit.RetryRule
 
ApplyFunction<K,VV,M> - Class in org.apache.flink.graph.gsa
The base class for the third and last step of a GatherSumApplyIteration.
ApplyFunction() - Constructor for class org.apache.flink.graph.gsa.ApplyFunction
 
applyIteratorTrueAssumption() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
applyOverlays(Configuration, ContainerSpecification) - Static method in class org.apache.flink.mesos.entrypoint.MesosEntrypointUtils
Generate a container specification as a TaskManager template.
applyPredicate(List<Expression>) - Method in class org.apache.flink.orc.OrcTableSource
 
applyRegistrations(Kryo, Collection<KryoRegistration>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
Apply a list of KryoRegistration to a Kryo instance.
applyRepartitioner(OperatorID, OperatorStateRepartitioner, List<OperatorStateHandle>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
applyRepartitioner(OperatorStateRepartitioner, List<OperatorStateHandle>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Repartitions the given operator state using the given OperatorStateRepartitioner with respect to the new parallelism.
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.
applyToAllWhileSuppressingExceptions(Iterable<T>, ThrowingConsumer<T>) - Static method in class org.apache.flink.util.LambdaUtil
This method supplies all elements from the input to the consumer.
archive() - Method in interface org.apache.flink.api.common.Archiveable
 
archive() - Method in class org.apache.flink.api.common.ExecutionConfig
 
archive() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.WebOptions
The config parameter defining the number of archived jobs for the jobmanager.
ARCHIVE_DIR - Static variable in class org.apache.flink.configuration.JobManagerOptions
The location where the JobManager stores the archives of completed jobs.
ARCHIVE_NAME - Static variable in class org.apache.flink.runtime.jobmaster.JobMaster
 
Archiveable<T extends Serializable> - Interface in org.apache.flink.api.common
 
ArchivedExecution - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecution(Execution) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
ArchivedExecution(StringifiedAccumulatorResult[], IOMetrics, ExecutionAttemptID, int, ExecutionState, String, TaskManagerLocation, int, long[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
ArchivedExecutionConfig - Class in org.apache.flink.api.common
Serializable class which is created when archiving the job.
ArchivedExecutionConfig(ExecutionConfig) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
 
ArchivedExecutionConfig(String, String, int, boolean, Map<String, String>) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
 
ArchivedExecutionGraph - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecutionGraph(JobID, String, Map<JobVertexID, ArchivedExecutionJobVertex>, List<ArchivedExecutionJobVertex>, long[], JobStatus, ErrorInfo, String, StringifiedAccumulatorResult[], Map<String, SerializedValue<Object>>, ArchivedExecutionConfig, boolean, CheckpointCoordinatorConfiguration, CheckpointStatsSnapshot) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
ArchivedExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecutionJobVertex(ExecutionJobVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
ArchivedExecutionJobVertex(ArchivedExecutionVertex[], JobVertexID, String, int, int, StringifiedAccumulatorResult[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
ArchivedExecutionVertex - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecutionVertex(ExecutionVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
ArchivedExecutionVertex(int, String, ArchivedExecution, EvictingBoundedList<ArchivedExecution>) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
ArchivedJson - Class in org.apache.flink.runtime.webmonitor.history
A simple container for a handler's JSON response and the REST URLs for which the response would've been returned.
ArchivedJson(String, String) - Constructor for class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
archiveJob(Path, AccessExecutionGraph) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
Writes the given AccessExecutionGraph to the FileSystem pointed to by JobManagerOptions.ARCHIVE_DIR.
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler.CheckpointConfigJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler.CheckpointStatsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.CurrentJobsOverviewHandler.CurrentJobsOverviewJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler.JobAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler.JobConfigJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler.JobDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler.JobExceptionsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobPlanHandler.JobPlanJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler.JobVertexAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler.JobVertexDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler.JobVertexTaskManagersJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler.SubtasksTimesJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in interface org.apache.flink.runtime.webmonitor.history.JsonArchivist
Returns a Collection of ArchivedJsons containing JSON responses and their respective REST URL for a given job.
areBranchCompatible(PlanNode, PlanNode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Checks whether to candidate plans for the sub-plan of this node are comparable.
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
areCompatible(Keys<?>) - Method in class org.apache.flink.api.common.operators.Keys
Check if two sets of keys are compatible to each other (matching types, key counts)
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
areExplicitEnvironmentsAllowed() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a RemoteEnvironment.
areFieldsUnique(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
Checks whether the given set of fields is unique, as specified in these local properties.
ARG_CONVERSION_DURATION - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_CONVERSION_RATE - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_DMAX - Static variable in class org.apache.flink.metrics.ganglia.GangliaReporter
 
ARG_HOST - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_HOST - Static variable in class org.apache.flink.metrics.statsd.StatsDReporter
 
ARG_MODE_ADDRESSING - Static variable in class org.apache.flink.metrics.ganglia.GangliaReporter
 
ARG_PORT - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_PORT - Static variable in class org.apache.flink.metrics.jmx.JMXReporter
 
ARG_PORT - Static variable in class org.apache.flink.metrics.statsd.StatsDReporter
 
ARG_PREFIX - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_PROTOCOL - Static variable in class org.apache.flink.metrics.graphite.GraphiteReporter
 
ARG_TMAX - Static variable in class org.apache.flink.metrics.ganglia.GangliaReporter
 
ARG_TTL - Static variable in class org.apache.flink.metrics.ganglia.GangliaReporter
 
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.
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.formats.avro.utils.DataInputDecoder
 
arrayToMap(String[]) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
arrayToString(Object) - Static method in class org.apache.flink.util.StringUtils
Returns a string representation of the given array.
Artifact(Path, Path, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
ARTIFACT_SERVER_PORT - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
The config parameter defining the Mesos artifact server port to use.
ARTIFACT_SERVER_SSL_ENABLED - Static variable in class org.apache.flink.mesos.configuration.MesosOptions
Config parameter to override SSL support for the Artifact Server.
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.
ascending - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
ascendingComparison - Variable in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions
Deprecated.
AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
Deprecated.
 
AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
A timestamp assigner and watermark generator for streams where timestamps are monotonously ascending.
AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
 
AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Handler that fails the program when timestamp monotony is violated.
AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Handler that does nothing when timestamp monotony is violated.
AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Handler that only logs violations of timestamp monotony, on WARN log level.
AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions.timestamps
Interface for handlers that handle violations of the monotonous ascending timestamps property.
asFile(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
asFlinkTuples() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
Specifies that the InputFormat returns Flink tuples instead of HCatRecord.
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.
ask(Object, Time) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
Timeout for akka ask calls.
asLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a LatencyMarker.
asQueryableState(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as queryable ValueState instance.
asQueryableState(String, ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as a queryable ValueState instance.
asQueryableState(String, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Deprecated.
will be removed in a future version
asQueryableState(String, ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as a queryable ReducingState instance.
asRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a StreamRecord.
asResultCollection() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
Return this async result as a async result collection.
asResultCollection() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
assign(KafkaTopicPartition, int) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionAssigner
Returns the index of the target subtask that a specific Kafka partition should be assigned to.
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.
assignExclusiveSegments(NetworkBufferPool, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Assign the exclusive buffers to all remote input channels directly for credit-based mode.
assignKeyToParallelOperator(Object, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a parallel operator index.
assignPartition(int, byte) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Assigns a partition to a bucket.
assignPartitions(KafkaConsumer<?, ?>, List<TopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge
 
assignPartitions(KafkaConsumer<?, ?>, List<TopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010
 
assignPendingSlotRequest(PendingSlotRequest) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
AssignRangeIndex<IN> - Class in org.apache.flink.runtime.operators.udf
This mapPartition function require a DataSet with RangeBoundaries as broadcast input, it generate Tuple2 which includes range index and record itself as output.
AssignRangeIndex(TypeComparatorFactory<IN>) - Constructor for class org.apache.flink.runtime.operators.udf.AssignRangeIndex
 
assignStates() - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
assignTimestamps(TimestampExtractor<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Assigns timestamps to the elements in the data stream and periodically creates watermarks to signal event time progress.
assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Assigns timestamps to the elements in the data stream and creates watermarks to signal event time progress based on the elements themselves.
assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies an AssignerWithPunctuatedWatermarks to emit watermarks in a punctuated manner.
assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies an AssignerWithPunctuatedWatermarks to emit watermarks in a punctuated manner.
assignToKeyGroup(Object, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a key-group index.
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns a Collection of windows that should be assigned to the element.
asStreamStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a StreamStatus.
asVariable(String) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
Formats the given string to resemble a scope variable.
asWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
Return this async result as a async watermark result.
asWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a Watermark.
AsyncCollectionResult<T> - Interface in org.apache.flink.streaming.api.operators.async.queue
AsyncResult sub class for asynchronous result collections.
AsyncDataStream - Class in org.apache.flink.streaming.api.datastream
A helper class to apply AsyncFunction to a data stream.
AsyncDataStream() - Constructor for class org.apache.flink.streaming.api.datastream.AsyncDataStream
 
AsyncDataStream.OutputMode - Enum in org.apache.flink.streaming.api.datastream
Output mode for asynchronous operations.
AsyncDoneCallback - Interface in org.apache.flink.runtime.io.async
Callback for an asynchronous operation that is called on termination
asyncException - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Errors encountered in the async producer are stored here.
AsyncExceptionHandler - Interface in org.apache.flink.streaming.runtime.tasks
An interface marking a task as capable of handling exceptions thrown by different threads, other than the one executing the task itself.
AsyncFunction<IN,OUT> - Interface in org.apache.flink.streaming.api.functions.async
A function to trigger Async I/O operation.
AsynchronousBlockReader - Class in org.apache.flink.runtime.io.disk.iomanager
A reader that reads data in blocks from a file channel.
AsynchronousBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, LinkedBlockingQueue<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
Creates a new block channel reader for the given channel.
AsynchronousBlockWriter - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBlockWriter(FileIOChannel.ID, RequestQueue<WriteRequest>, LinkedBlockingQueue<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
Creates a new block channel writer for the given channel.
AsynchronousBlockWriterWithCallback - Class in org.apache.flink.runtime.io.disk.iomanager
An asynchronous implementation of the BlockChannelWriterWithCallback that queues I/O requests and calls a callback once they have been handled.
AsynchronousBlockWriterWithCallback(FileIOChannel.ID, RequestQueue<WriteRequest>, RequestDoneCallback<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriterWithCallback
Creates a new asynchronous block writer for the given channel.
AsynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBufferFileReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<Buffer>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
AsynchronousBufferFileSegmentReader - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBufferFileSegmentReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<FileSegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
AsynchronousBufferFileWriter - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBufferFileWriter(FileIOChannel.ID, RequestQueue<WriteRequest>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
 
AsynchronousBulkBlockReader - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBulkBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
 
AsynchronousException - Exception in org.apache.flink.streaming.runtime.tasks
An exception for wrapping exceptions that are thrown by an operator in threads other than the main compute thread of that operator.
AsynchronousException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
 
AsynchronousException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
 
AsynchronousFileIOChannel<T,R extends org.apache.flink.runtime.io.disk.iomanager.IORequest> - Class in org.apache.flink.runtime.io.disk.iomanager
A base class for readers and writers that accept read or write requests for whole blocks.
AsynchronousFileIOChannel(FileIOChannel.ID, RequestQueue<R>, RequestDoneCallback<T>, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Creates a new channel access to the path indicated by the given ID.
asyncInvoke(IN, ResultFuture<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
Trigger async operation for each stream input.
asyncInvoke(IN, ResultFuture<OUT>) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
AsyncIOExample - Class in org.apache.flink.streaming.examples.async
Example to illustrates how to use AsyncFunction.
AsyncIOExample() - Constructor for class org.apache.flink.streaming.examples.async.AsyncIOExample
 
AsyncResult - Interface in org.apache.flink.streaming.api.operators.async.queue
Asynchronous result returned by the StreamElementQueue.
AsyncStoppable - Interface in org.apache.flink.runtime.io.async
An asynchronous operation that can be stopped.
AsyncStoppableTaskWithCallback<V> - Class in org.apache.flink.runtime.io.async
 
AsyncStoppableTaskWithCallback(StoppableCallbackCallable<V>) - Constructor for class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
AsyncWaitOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
The AsyncWaitOperator allows to asynchronously process incoming stream records.
AsyncWaitOperator(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
AsyncWatermarkResult - Interface in org.apache.flink.streaming.api.operators.async.queue
AsyncResult subclass for asynchronous result Watermark.
AtomicDisposableReferenceCounter - Class in org.apache.flink.runtime.util
Atomic reference counter, which enters a "disposed" state after it reaches a configurable reference count (default 0).
AtomicDisposableReferenceCounter() - Constructor for class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
AtomicDisposableReferenceCounter(int) - Constructor for class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
AtomicKvStateRequestStats - Class in org.apache.flink.queryablestate.network.stats
Atomic KvStateRequestStats implementation.
AtomicKvStateRequestStats() - Constructor for class org.apache.flink.queryablestate.network.stats.AtomicKvStateRequestStats
 
AtomicType<T> - Interface in org.apache.flink.api.common.typeinfo
An atomic type is a type that is treated as one indivisible unit and where the entire type acts as a key.
attachJobGraph(List<JobVertex>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
attachToRunningJob(JobID, Configuration, ActorSystem, HighAvailabilityServices, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobClient
Attaches to a running Job using the JobID.
attemptNumber() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
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
 
autoAck - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
auxiliary(SqlKind) - Method in class org.apache.calcite.sql.fun.SqlGroupFunction
Creates an auxiliary function from this grouped window function.
auxiliary(String, SqlKind) - Method in class org.apache.calcite.sql.fun.SqlGroupFunction
Creates an auxiliary function from this grouped window function.
AuxiliaryConverter - Interface in org.apache.calcite.sql2rel
Converts an expression for a group window function (e.g.
AuxiliaryConverter.Impl - Class in org.apache.calcite.sql2rel
Simple implementation of AuxiliaryConverter.
available() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
available() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
available() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
available() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
available() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
available() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
available() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
 
availableMemory - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The free memory segments currently available to the hash join.
AverageAccumulator - Class in org.apache.flink.api.common.accumulators
An accumulator that computes the average value.
AverageAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.AverageAccumulator
 
AverageClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
The average clustering coefficient measures the mean connectedness of a graph.
AverageClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient
 
AverageClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
The average clustering coefficient measures the mean connectedness of a graph.
AverageClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient
 
AverageClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.directed
Wraps global clustering coefficient metrics.
AverageClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.undirected
Wraps global clustering coefficient metrics.
AVG_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
 
AvroInputFormat<E> - Class in org.apache.flink.formats.avro
Provides a FileInputFormat for Avro records.
AvroInputFormat(Path, Class<E>) - Constructor for class org.apache.flink.formats.avro.AvroInputFormat
 
AvroKeyValue(GenericRecord) - Constructor for class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
Wraps a GenericRecord that is a key value pair.
AvroKeyValueSinkWriter<K,V> - Class in org.apache.flink.streaming.connectors.fs
Implementation of AvroKeyValue writer that can be used in Sink.
AvroKeyValueSinkWriter(Map<String, String>) - Constructor for class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
C'tor for the writer.
AvroKeyValueSinkWriter(AvroKeyValueSinkWriter<K, V>) - Constructor for class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
AvroKeyValueSinkWriter.AvroKeyValue<K,V> - Class in org.apache.flink.streaming.connectors.fs
A reusable Avro generic record for writing key/value pairs to the file.
AvroKryoSerializerUtils - Class in org.apache.flink.formats.avro.utils
Utilities for integrating Avro serializers in Kryo.
AvroKryoSerializerUtils() - Constructor for class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils
 
AvroKryoSerializerUtils.AvroSchemaSerializer - Class in org.apache.flink.formats.avro.utils
Slow serialization approach for Avro schemas.
AvroOutputFormat<E> - Class in org.apache.flink.formats.avro
FileOutputFormat for Avro records.
AvroOutputFormat(Path, Class<E>) - Constructor for class org.apache.flink.formats.avro.AvroOutputFormat
 
AvroOutputFormat(Class<E>) - Constructor for class org.apache.flink.formats.avro.AvroOutputFormat
 
AvroOutputFormat.Codec - Enum in org.apache.flink.formats.avro
Wrapper which encapsulates the supported codec and a related serialization byte.
AvroRowDeserializationSchema - Class in org.apache.flink.formats.avro
Deserialization schema from Avro bytes over SpecificRecord to Row.
AvroRowDeserializationSchema(Class<? extends SpecificRecord>) - Constructor for class org.apache.flink.formats.avro.AvroRowDeserializationSchema
Creates a Avro deserialization schema for the given record.
AvroRowSerializationSchema - Class in org.apache.flink.formats.avro
Serialization schema that serializes Row over SpecificRecord into a Avro bytes.
AvroRowSerializationSchema(Class<? extends SpecificRecord>) - Constructor for class org.apache.flink.formats.avro.AvroRowSerializationSchema
Creates a Avro serialization schema for the given schema.
AvroSchemaSerializer() - Constructor for class org.apache.flink.formats.avro.utils.AvroKryoSerializerUtils.AvroSchemaSerializer
 
AvroSchemaSerializerConfigSnapshot() - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot
Default constructor for instantiation via reflection.
AvroSchemaSerializerConfigSnapshot(String) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSchemaSerializerConfigSnapshot
 
AvroSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
AvroSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
Deprecated.
 
AvroSerializer(Class<T>, Class<? extends T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
Deprecated.
 
AvroSerializer<T> - Class in org.apache.flink.formats.avro.typeutils
A serializer that serializes types via Avro.
AvroSerializer(Class<T>) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer
Creates a new AvroSerializer for the type indicated by the given class.
AvroSerializer(Class<T>, Class<? extends T>) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer
Deprecated.
AvroSerializer.AvroSchemaSerializerConfigSnapshot - Class in org.apache.flink.formats.avro.typeutils
A config snapshot for the Avro Serializer that stores the Avro Schema to check compatibility.
AvroSerializer.AvroSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
Config snapshot for this serializer.
AvroSerializer.AvroSerializerConfigSnapshot<T> - Class in org.apache.flink.formats.avro.typeutils
Deprecated.
AvroSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
Deprecated.
 
AvroSerializerConfigSnapshot(Class<T>, Class<? extends T>, LinkedHashMap<String, KryoRegistration>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
Deprecated.
 
AvroSerializerConfigSnapshot() - Constructor for class org.apache.flink.formats.avro.typeutils.AvroSerializer.AvroSerializerConfigSnapshot
Deprecated.
 
AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase> - Class in org.apache.flink.api.java.typeutils
Deprecated.
Please use org.apache.flink.formats.avro.typeutils.AvroTypeInfo in the flink-avro module. This class will be removed in the near future.
AvroTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.AvroTypeInfo
Deprecated.
 
AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase> - Class in org.apache.flink.formats.avro.typeutils
Special type information to generate a special AvroTypeInfo for Avro POJOs (implementing SpecificRecordBase, the typed Avro POJOs)
AvroTypeInfo(Class<T>) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroTypeInfo
Creates a new Avro type info for the given class.
AvroTypeInfo(Class<T>, boolean) - Constructor for class org.apache.flink.formats.avro.typeutils.AvroTypeInfo
Creates a new Avro type info for the given class.
AvroUtils - Class in org.apache.flink.api.java.typeutils
Utility methods for dealing with Avro types.
AvroUtils() - Constructor for class org.apache.flink.api.java.typeutils.AvroUtils
 
await() - Method in class org.apache.flink.core.testutils.MultiShotLatch
Waits until MultiShotLatch.trigger() is called.
await() - Method in class org.apache.flink.core.testutils.OneShotLatch
Waits until OneShotLatch.trigger() is called.
await(long, TimeUnit) - Method in class org.apache.flink.core.testutils.OneShotLatch
Waits until OneShotLatch.trigger() is called.
awaitJobResult(JobListeningContext) - Static method in class org.apache.flink.runtime.client.JobClient
Given a JobListeningContext, awaits the result of the job execution that this context is bound to
awaitPendingAfterQuiesce() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
This method can be used after calling ProcessingTimeService.quiesce(), and awaits the completion of currently executing timers.
awaitPendingAfterQuiesce() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
awaitPendingAfterQuiesce() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
awaitStartOfSuperstepOrTermination(int) - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 

B

back() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
backend - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Backend that holds the actual RocksDB instance where we store state.
BACKPRESSURE_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.WebOptions
Time after which cached stats are cleaned up if not accessed.
BACKPRESSURE_DELAY - Static variable in class org.apache.flink.configuration.WebOptions
Delay between stack trace samples to determine back pressure.
BACKPRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.WebOptions
Number of stack trace samples to take to determine back pressure.
BACKPRESSURE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.WebOptions
Time after which available stats are deprecated and need to be refreshed (by resampling).
BackPressureStatsTracker - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
Back pressure statistics tracker.
BackPressureStatsTracker(StackTraceSampleCoordinator, int, int, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
Creates a back pressure statistics tracker.
BackwardsCompatibleAvroSerializer<T> - Class in org.apache.flink.formats.avro.typeutils
An Avro serializer that can switch back to a KryoSerializer or a Pojo Serializer, if it has to ensure compatibility with one of those.
BackwardsCompatibleAvroSerializer(Class<T>) - Constructor for class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
Creates a new backwards-compatible Avro Serializer, for the given type.
BadRequestException - Exception in org.apache.flink.queryablestate.network
Base class for exceptions thrown during querying Flink's managed state.
BadRequestException(String, String) - Constructor for exception org.apache.flink.queryablestate.network.BadRequestException
 
BarrierBuffer - Class in org.apache.flink.streaming.runtime.io
The barrier buffer is CheckpointBarrierHandler that blocks inputs with barriers until all inputs have received the barrier for a given checkpoint.
BarrierBuffer(InputGate, IOManager) - Constructor for class org.apache.flink.streaming.runtime.io.BarrierBuffer
Creates a new checkpoint stream aligner.
BarrierBuffer(InputGate, IOManager, long) - Constructor for class org.apache.flink.streaming.runtime.io.BarrierBuffer
Creates a new checkpoint stream aligner.
BarrierTracker - Class in org.apache.flink.streaming.runtime.io
The BarrierTracker keeps track of what checkpoint barriers have been received from which input channels.
BarrierTracker(InputGate) - Constructor for class org.apache.flink.streaming.runtime.io.BarrierTracker
 
BaseAlignedWindowAssigner - Class in org.apache.flink.streaming.api.windowing.assigners
A base WindowAssigner used to instantiate one of the deprecated AccumulatingProcessingTimeWindowOperator and AggregatingProcessingTimeWindowOperator.
BaseAlignedWindowAssigner(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
 
BasePathBucketer<T> - Class in org.apache.flink.streaming.connectors.fs.bucketing
A Bucketer that does not perform any bucketing of files.
BasePathBucketer() - Constructor for class org.apache.flink.streaming.connectors.fs.bucketing.BasePathBucketer
 
BaseStatistics - Interface in org.apache.flink.api.common.io.statistics
Interface describing the basic statistics that can be obtained from the input.
baseURL() - Method in class org.apache.flink.mesos.util.MesosArtifactServer
 
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, Void, BigInteger, and BigDecimal.
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
 
begin(String) - Static method in class org.apache.flink.cep.pattern.Pattern
Starts a new pattern sequence.
begin(String, AfterMatchSkipStrategy) - Static method in class org.apache.flink.cep.pattern.Pattern
Starts a new pattern sequence.
begin(Pattern<T, F>, AfterMatchSkipStrategy) - Static method in class org.apache.flink.cep.pattern.Pattern
Starts a new pattern sequence.
begin(Pattern<T, F>) - Static method in class org.apache.flink.cep.pattern.Pattern
Starts a new pattern sequence.
beginTransaction() - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction
Method that starts a new transaction.
beginTransaction() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011
 
beginTransaction() - Method in class org.apache.flink.streaming.connectors.kafka.internal.FlinkKafkaProducer
 
BernoulliSampler<T> - Class in org.apache.flink.api.java.sampling
A sampler implementation built upon a Bernoulli trail.
BernoulliSampler(double) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and default random number generator.
BernoulliSampler(double, long) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator seed.
BernoulliSampler(double, Random) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator.
bestEffortDiscardAllStateObjects(Iterable<? extends StateObject>) - Static method in class org.apache.flink.runtime.state.StateUtil
Iterates through the passed state handles and calls discardState() on each handle that is not null.
bestEffortGetNumOfUsedBuffers() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the number of used buffers of this buffer pool.
Between(String, PredicateLeaf.Type, Serializable, Serializable) - Constructor for class org.apache.flink.orc.OrcRowInputFormat.Between
Creates an BETWEEN predicate.
BIG_DEC_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BIG_INT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BigDecComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing BigDecimal values.
BigDecComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
BigDecParser - Class in org.apache.flink.types.parser
Parses a text field into a BigDecimal.
BigDecParser() - Constructor for class org.apache.flink.types.parser.BigDecParser
 
BigDecSerializer - Class in org.apache.flink.api.common.typeutils.base
Serializer for serializing/deserializing BigDecimal values including null values.
BigDecSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
BigIntComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing BigInteger values.
BigIntComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
BigIntParser - Class in org.apache.flink.types.parser
Parses a text field into a BigInteger.
BigIntParser() - Constructor for class org.apache.flink.types.parser.BigIntParser
 
BigIntSerializer - Class in org.apache.flink.api.common.typeutils.base
Serializer for serializing/deserializing BigInteger values including null values.
BigIntSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
BinaryInputFormat<T> - Class in org.apache.flink.api.common.io
Base class for all input formats that use blocks of fixed size.
BinaryInputFormat() - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat
 
BinaryInputFormat.BlockBasedInput - Class in org.apache.flink.api.common.io
Reads the content of a block of data.
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.
BinaryResult<K> - Interface in org.apache.flink.graph.asm.result
A GraphAlgorithm result for a pair vertices.
BinaryResult.MirrorResult<T,RT extends BinaryResult<T>> - Class in org.apache.flink.graph.asm.result
Output each input and a second result with the vertex order flipped.
BinaryResultBase<K> - Class in org.apache.flink.graph.asm.result
Base class for algorithm results for a pair of vertices.
BinaryResultBase() - Constructor for class org.apache.flink.graph.asm.result.BinaryResultBase
 
BinaryUnionNode - Class in org.apache.flink.optimizer.dag
The Optimizer representation of a binary Union.
BinaryUnionNode(Union<?>) - Constructor for class org.apache.flink.optimizer.dag.BinaryUnionNode
 
BinaryUnionNode.UnionSemanticProperties - Class in org.apache.flink.optimizer.dag
 
BinaryUnionOpDescriptor - Class in org.apache.flink.optimizer.operators
 
BinaryUnionOpDescriptor() - Constructor for class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
BinaryUnionPlanNode - Class in org.apache.flink.optimizer.plan
A special subclass for the union to make it identifiable.
BinaryUnionPlanNode(BinaryUnionNode, Channel, Channel) - Constructor for class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
 
BinaryUnionPlanNode(BinaryUnionPlanNode) - Constructor for class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
 
BinaryUnionReplacer - Class in org.apache.flink.optimizer.traversals
A traversal that collects cascading binary unions into a single n-ary union operator.
BinaryUnionReplacer() - Constructor for class org.apache.flink.optimizer.traversals.BinaryUnionReplacer
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.ListStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.MapStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.StateDescriptor
Creates a new State on the given StateBinder.
bind(StateBinder) - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
 
bindVariables(String[], String[]) - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
BipartiteEdge<KT,KB,EV> - Class in org.apache.flink.graph.bipartite
A BipartiteEdge represents a link between top and bottom vertices in a BipartiteGraph.
BipartiteEdge() - Constructor for class org.apache.flink.graph.bipartite.BipartiteEdge
 
BipartiteEdge(KT, KB, EV) - Constructor for class org.apache.flink.graph.bipartite.BipartiteEdge
 
BipartiteGraph<KT,KB,VVT,VVB,EV> - Class in org.apache.flink.graph.bipartite
The vertices of a bipartite graph are divided into two disjoint sets, referenced by the names "top" and "bottom".
bitMix(int) - Static method in class org.apache.flink.util.MathUtils
Bit-mixing for pseudo-randomization of integers (e.g., to guard against bad hash functions).
BitSet - Class in org.apache.flink.runtime.operators.util
 
BitSet(int) - Constructor for class org.apache.flink.runtime.operators.util.BitSet
 
bitSet - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
 
BitSet(int) - Constructor for class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
bitSize() - Method in class org.apache.flink.runtime.operators.util.BitSet
Number of bits
bitSize() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Number of bits
BLOB_FETCH_BACKLOG_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_FETCH_CONCURRENT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_FETCH_RETRIES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_SERVER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_SERVICE_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_STORAGE_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BlobCacheService - Class in org.apache.flink.runtime.blob
The BLOB cache provides access to BLOB services for permanent and transient BLOBs.
BlobCacheService(InetSocketAddress, Configuration, BlobView) - Constructor for class org.apache.flink.runtime.blob.BlobCacheService
Instantiates a new BLOB cache.
BlobCacheService(PermanentBlobCache, TransientBlobCache) - Constructor for class org.apache.flink.runtime.blob.BlobCacheService
Instantiates a new BLOB cache.
BlobClient - Class in org.apache.flink.runtime.blob
The BLOB client can communicate with the BLOB server and either upload (PUT), download (GET), or delete (DELETE) BLOBs.
BlobClient(InetSocketAddress, Configuration) - Constructor for class org.apache.flink.runtime.blob.BlobClient
Instantiates a new BLOB client.
blobClientConfig - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
Configuration for the blob client like ssl parameters required to connect to the blob server.
BlobLibraryCacheManager - Class in org.apache.flink.runtime.execution.librarycache
Provides facilities to download a set of libraries (typically JAR files) for a job from a PermanentBlobService and create a class loader with references to them.
BlobLibraryCacheManager(PermanentBlobService, FlinkUserCodeClassLoaders.ResolveOrder, String[]) - Constructor for class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
BlobServer - Class in org.apache.flink.runtime.blob
This class implements the BLOB server.
BlobServer(Configuration, BlobStore) - Constructor for class org.apache.flink.runtime.blob.BlobServer
Instantiates a new BLOB server and binds it to a free network port.
blobServer - Variable in class org.apache.flink.runtime.jobmaster.JobManagerServices
 
BlobServerOptions - Class in org.apache.flink.configuration
Configuration options for the BlobServer and BlobCache.
BlobServerOptions() - Constructor for class org.apache.flink.configuration.BlobServerOptions
 
BlobServerPortHandler - Class in org.apache.flink.runtime.rest.handler.job
This handler can be used to retrieve the port that the blob server runs on.
BlobServerPortHandler(CompletableFuture<String>, GatewayRetriever<DispatcherGateway>, Time) - Constructor for class org.apache.flink.runtime.rest.handler.job.BlobServerPortHandler
 
BlobServerPortHeaders - Class in org.apache.flink.runtime.rest.messages
These headers define the protocol for querying the port of the blob server.
BlobServerPortResponseBody - Class in org.apache.flink.runtime.rest.messages
Response containing the blob server port.
BlobServerPortResponseBody(int) - Constructor for class org.apache.flink.runtime.rest.messages.BlobServerPortResponseBody
 
BlobServerProtocol - Class in org.apache.flink.runtime.blob
 
BlobService - Interface in org.apache.flink.runtime.blob
A simple store and retrieve binary large objects (BLOBs).
BlobStore - Interface in org.apache.flink.runtime.blob
A blob store.
BlobStoreService - Interface in org.apache.flink.runtime.blob
Service interface for the BlobStore which allows to close and clean up its data.
blobStoreService - Variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
Blob store service to be used for the BlobServer and BlobCache.
BlobUtils - Class in org.apache.flink.runtime.blob
Utility class to work with blob data.
blobView - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
Blob store for distributed file storage, e.g.
BlobView - Interface in org.apache.flink.runtime.blob
View on blobs stored in a BlobStore.
BlobWriter - Interface in org.apache.flink.runtime.blob
BlobWriter is used to upload data to the BLOB store.
BLOCK_SIZE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.BinaryInputFormat
The config parameter which defines the fixed length of a record.
BLOCK_SIZE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.BinaryOutputFormat
The config parameter which defines the fixed length of a record.
BlockBasedInput(FSDataInputStream, int) - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
BlockBasedInput(FSDataInputStream, int, long) - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
BlockBasedOutput(OutputStream, int) - Constructor for class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
BlockChannelReader<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
A reader that reads data in blocks from a file channel.
BlockChannelWriter<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
A writer that writes data in blocks to a file channel.
BlockChannelWriterWithCallback<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
 
blockForeverNonInterruptibly() - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Permanently blocks the current thread.
blockHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
BlockInfo - Class in org.apache.flink.api.common.io
A block of 24 bytes written at the end of a block in a binary file, and containing i) the number of records in the block, ii) the accumulated number of records, and iii) the offset of the first record in the block.
BlockInfo() - Constructor for class org.apache.flink.api.common.io.BlockInfo
 
BlockInfo<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator.random
Defines a source of randomness and a unit of work.
BlockInfo(RandomGenerable<T>, int, int, long, long) - Constructor for class org.apache.flink.graph.generator.random.BlockInfo
 
BlockingBackChannel - Class in org.apache.flink.runtime.iterative.concurrent
A concurrent datastructure that establishes a backchannel buffer between an iteration head and an iteration tail.
BlockingBackChannel(SerializedUpdateBuffer) - Constructor for class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
 
BlockingBackChannelBroker - Class in org.apache.flink.runtime.iterative.concurrent
Singleton class for the threadsafe handover of BlockingBackChannels from iteration heads to iteration tails.
BlockingQueueBroker - Class in org.apache.flink.streaming.runtime.io
Broker for the BlockingQueue used in StreamIterationHead and StreamIterationTail for implementing feedback streams.
BlockLocation - Interface in org.apache.flink.core.fs
A BlockLocation lists hosts, offset and length of block.
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
 
blockTraffic() - Method in class org.apache.flink.networking.NetworkFailuresProxy
Blocks all ongoing traffic, closes all ongoing and closes any new incoming connections.
BloomFilter - Class in org.apache.flink.runtime.operators.util
BloomFilter is a probabilistic data structure for set membership check.
BloomFilter(int, int) - Constructor for class org.apache.flink.runtime.operators.util.BloomFilter
 
BloomFilter.BitSet - Class in org.apache.flink.runtime.operators.util
Bare metal bit set implementation.
body - Variable in class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
 
bolt - Variable in class org.apache.flink.storm.wrappers.BoltWrapper
The wrapped Storm bolt.
BoltCounter - Class in org.apache.flink.storm.wordcount.operators
Implements the word counter that counts the occurrence of each unique word.
BoltCounter() - Constructor for class org.apache.flink.storm.wordcount.operators.BoltCounter
 
BoltCounterByName - Class in org.apache.flink.storm.wordcount.operators
Implements the word counter that counts the occurrence of each unique word.
BoltCounterByName() - Constructor for class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
BoltFileSink - Class in org.apache.flink.storm.util
Implements a sink that write the received data to the given file (as a result of Object.toString() for each attribute).
BoltFileSink(String) - Constructor for class org.apache.flink.storm.util.BoltFileSink
 
BoltFileSink(String, OutputFormatter) - Constructor for class org.apache.flink.storm.util.BoltFileSink
 
BoltPrintSink - Class in org.apache.flink.storm.util
Implements a sink that prints the received data to stdout.
BoltPrintSink(OutputFormatter) - Constructor for class org.apache.flink.storm.util.BoltPrintSink
 
BoltTokenizer - Class in org.apache.flink.storm.wordcount.operators
Implements the string tokenizer that splits sentences into words as a bolt.
BoltTokenizer() - Constructor for class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
BoltTokenizerByName - Class in org.apache.flink.storm.wordcount.operators
Implements the string tokenizer that splits sentences into words as a bolt.
BoltTokenizerByName() - Constructor for class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
BoltTokenizerWordCount - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
BoltTokenizerWordCount() - Constructor for class org.apache.flink.storm.wordcount.BoltTokenizerWordCount
 
BoltTokenizerWordCountPojo - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
BoltTokenizerWordCountPojo() - Constructor for class org.apache.flink.storm.wordcount.BoltTokenizerWordCountPojo
 
BoltTokenizerWordCountWithNames - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
BoltTokenizerWordCountWithNames() - Constructor for class org.apache.flink.storm.wordcount.BoltTokenizerWordCountWithNames
 
BoltWrapper<IN,OUT> - Class in org.apache.flink.storm.wrappers
A BoltWrapper wraps an IRichBolt in order to execute the Storm bolt within a Flink Streaming program.
BoltWrapper(IRichBolt) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, Fields) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, String[]) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, Fields, String[]) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, Fields, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, String, String, String, Fields, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BOOLEAN - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
BOOLEAN_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
BOOLEAN_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
BOOLEAN_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BOOLEAN_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
BooleanColumnSummary - Class in org.apache.flink.api.java.summarize
Summary for a column of booleans.
BooleanColumnSummary(long, long, long) - Constructor for class org.apache.flink.api.java.summarize.BooleanColumnSummary
 
BooleanComparator - Class in org.apache.flink.api.common.typeutils.base
 
BooleanComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
BooleanConditions - Class in org.apache.flink.cep.pattern.conditions
Utility class containing an IterativeCondition that always returns true and one that always returns false.
BooleanConditions() - Constructor for class org.apache.flink.cep.pattern.conditions.BooleanConditions
 
BooleanParameter - Class in org.apache.flink.graph.drivers.parameter
A Parameter storing a Boolean.
BooleanParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.BooleanParameter
Set the parameter name and add this parameter to the list of parameters stored by owner.
BooleanParser - Class in org.apache.flink.types.parser
 
BooleanParser() - Constructor for class org.apache.flink.types.parser.BooleanParser
 
BooleanPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
BooleanPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
BooleanPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for boolean arrays.
BooleanPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
BooleanSerializer - Class in org.apache.flink.api.common.typeutils.base
 
BooleanSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
BooleanSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
 
BooleanSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for Boolean type.
BooleanSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
BooleanValue - Class in org.apache.flink.types
Boxed serializable and comparable boolean type, representing the primitive type boolean.
BooleanValue() - Constructor for class org.apache.flink.types.BooleanValue
 
BooleanValue(boolean) - Constructor for class org.apache.flink.types.BooleanValue
 
BooleanValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for BooleanValue based on CopyableValueComparator.
BooleanValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
BooleanValueParser - Class in org.apache.flink.types.parser
 
BooleanValueParser() - Constructor for class org.apache.flink.types.parser.BooleanValueParser
 
BooleanValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
BooleanValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
BooleanValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
bootstrapCommand() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the bootstrap command.
BootstrapTools - Class in org.apache.flink.runtime.clusterframework
Tools for starting JobManager and TaskManager processes, including the Actor Systems used to run the JobManager and TaskManager actors.
BoundedInputStream - Class in org.apache.flink.runtime.state
Wrapper around a FSDataInputStream to limit the maximum read offset.
BoundedInputStream(FSDataInputStream, long) - Constructor for class org.apache.flink.runtime.state.BoundedInputStream
 
BoundedOutOfOrdernessTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
This is a AssignerWithPeriodicWatermarks used to emit Watermarks that lag behind the element with the maximum timestamp (in event time) seen so far by a fixed amount of time, t_late.
BoundedOutOfOrdernessTimestampExtractor(Time) - Constructor for class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
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
 
broadcast() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are broadcast to every parallel instance of the next operation.
broadcastCheckpointBarrier(long, long, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
broadcastCheckpointCancelMarker(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
broadcastEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
This is used to broadcast Streaming Watermarks in-band with records.
broadcastEmit(T) - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
 
broadcastEvent(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
broadcastEvent(AbstractEvent) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
broadcastInputReaders - Variable in class org.apache.flink.runtime.operators.BatchTask
The input readers for the configured broadcast variables for this task.
broadcastInputs - Variable in class org.apache.flink.api.common.operators.AbstractUdfOperator
The extra inputs which parameterize the user function.
broadcastInputSerializers - Variable in class org.apache.flink.runtime.operators.BatchTask
The serializers for the broadcast input data types.
BroadcastPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that selects all the output channels.
BroadcastPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
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
An identifier for a BroadcastVariableMaterialization based on the task's JobVertexID, broadcast variable name and iteration superstep.
BroadcastVariableKey(JobVertexID, String, int) - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
BroadcastVariableManager - Class in org.apache.flink.runtime.broadcast
The BroadcastVariableManager is used to manage the materialization of broadcast variables.
BroadcastVariableManager() - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
BroadcastVariableMaterialization<T,C> - Class in org.apache.flink.runtime.broadcast
This class represents a single materialization of a broadcast variable and maintains a reference count for it.
BroadcastVariableMaterialization(BroadcastVariableKey) - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
Broker<V> - Class in org.apache.flink.runtime.iterative.concurrent
A concurrent data structure that allows the hand-over of an object between a pair of threads.
Broker() - Constructor for class org.apache.flink.runtime.iterative.concurrent.Broker
 
brokerKey() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
Bucketer - Interface in org.apache.flink.streaming.connectors.fs
Deprecated.
use Bucketer instead.
Bucketer<T> - Interface in org.apache.flink.streaming.connectors.fs.bucketing
A bucketer is used with a BucketingSink to put emitted elements into rolling files.
BucketingSink<T> - Class in org.apache.flink.streaming.connectors.fs.bucketing
Sink that emits its input elements to FileSystem files within buckets.
BucketingSink(String) - Constructor for class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Creates a new BucketingSink that writes files to the given base directory.
buckets - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The array of memory segments that contain the buckets which form the actual hash-table of hash-codes and pointers to the elements.
bucketsPerSegmentBits - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The number of bits that describe the position of a bucket in a memory segment.
bucketsPerSegmentMask - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The number of hash table buckets in a single memory segment - 1.
BucketState() - Constructor for class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
Deprecated.
 
buffer - Variable in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
buffer - Variable in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
buffer - Variable in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
 
buffer() - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
 
buffer(int) - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
 
buffer(int, int) - Method in class org.apache.flink.queryablestate.network.NettyBufferPool
 
Buffer - Class in org.apache.flink.runtime.io.network.buffer
Wrapper for pooled MemorySegment instances.
Buffer(MemorySegment, BufferRecycler) - Constructor for class org.apache.flink.runtime.io.network.buffer.Buffer
 
Buffer(MemorySegment, BufferRecycler, boolean) - Constructor for class org.apache.flink.runtime.io.network.buffer.Buffer
 
buffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
buffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
buffer(int, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
buffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
buffer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
buffer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
BufferAndAvailability(Buffer, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
BufferAvailabilityListener - Interface in org.apache.flink.runtime.io.network.partition
Listener interface implemented by consumers of ResultSubpartitionView that want to be notified of availability of further buffers.
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
 
BufferListener - Interface in org.apache.flink.runtime.io.network.buffer
Interface of the availability of buffers.
BufferOrEvent - Class in org.apache.flink.runtime.io.network.partition.consumer
Either type for Buffer or AbstractEvent instances tagged with the channel index, from which they were received.
BufferOrEvent(Buffer, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
BufferOrEvent(AbstractEvent, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
BufferPool - Interface in org.apache.flink.runtime.io.network.buffer
A dynamically sized buffer pool.
BufferPoolFactory - Interface in org.apache.flink.runtime.io.network.buffer
A factory for buffer pools.
BufferPoolOwner - Interface in org.apache.flink.runtime.io.network.buffer
 
BufferProvider - Interface in org.apache.flink.runtime.io.network.buffer
A buffer provider to request buffers from in a synchronous or asynchronous fashion.
BufferRecycler - Interface in org.apache.flink.runtime.io.network.buffer
 
BufferSpiller - Class in org.apache.flink.streaming.runtime.io
The buffer spiller takes the buffers and events from a data stream and adds them to a spill file.
BufferSpiller(IOManager, int) - Constructor for class org.apache.flink.streaming.runtime.io.BufferSpiller
Creates a new buffer spiller, spilling to one of the I/O manager's temp directories.
BufferSpiller.SpilledBufferOrEventSequence - Class in org.apache.flink.streaming.runtime.io
This class represents a sequence of spilled buffers and events, created by the BufferSpiller.
bufferTimeout - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
build() - Method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSinkBuilder
Finalizes the configuration and checks validity.
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple15Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple16Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple17Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple18Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple20Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple21Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple22Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple23Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple24Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
build() - Method in interface org.apache.flink.mesos.scheduler.TaskSchedulerBuilder
Build a Fenzo task scheduler.
build() - Method in class org.apache.flink.orc.OrcTableSource.Builder
Builds the OrcTableSource for this builder.
build() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
build() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
Finalizes the configuration of this sink.
build() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource.Builder
Builds and configures a Kafka010AvroTableSource.
build() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource.Builder
Builds and configures a Kafka010JsonTableSource.
build() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource.Builder
Builds and configures a Kafka011AvroTableSource.
build() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource.Builder
Builds and configures a Kafka011JsonTableSource.
build() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource.Builder
Builds and configures a Kafka08AvroTableSource.
build() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource.Builder
Builds and configures a Kafka08JsonTableSource.
build() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource.Builder
Builds and configures a Kafka09AvroTableSource.
build() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource.Builder
Builds and configures a Kafka09JsonTableSource.
build() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
Builds the configured KafkaTableSource.
build() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
The Builder method.
buildBloomFilterForBucketsInPartition(int, HashPartition<BT, PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
buildBulkProcessor(BulkProcessor.Listener) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
Build the BulkProcessor.
buildCluster(Cluster.Builder) - Method in class org.apache.flink.streaming.connectors.cassandra.ClusterBuilder
Configures the connection to Cassandra.
builder() - Static method in class org.apache.flink.api.java.io.jdbc.JDBCAppendTableSink
 
builder() - Static method in class org.apache.flink.orc.OrcTableSource
 
Builder() - Constructor for class org.apache.flink.orc.OrcTableSource.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
builder - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
builder() - Static method in class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource
Returns a builder to configure and create a Kafka010AvroTableSource.
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource.Builder
 
builder() - Static method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource
Returns a builder to configure and create a Kafka010JsonTableSource.
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource.Builder
 
builder() - Static method in class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource
Returns a builder to configure and create a Kafka011AvroTableSource.
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011AvroTableSource.Builder
 
builder() - Static method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource
Returns a builder to configure and create a Kafka011JsonTableSource.
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka011JsonTableSource.Builder
 
builder() - Static method in class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource
Returns a builder to configure and create a Kafka08AvroTableSource.
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource.Builder
 
builder() - Static method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource
Returns a builder to configure and create a Kafka08JsonTableSource.
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource.Builder
 
builder() - Static method in class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource
Returns a builder to configure and create a Kafka09AvroTableSource.
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource.Builder
 
builder() - Static method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource
Returns a builder to configure and create a Kafka09JsonTableSource.
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource.Builder
 
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.KafkaAvroTableSource.Builder
 
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource.Builder
 
Builder() - Constructor for class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
 
builder() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource.Builder
Returns the builder.
Builder() - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
 
BuildFirstCachedJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
BuildFirstCachedJoinDriver() - Constructor for class org.apache.flink.runtime.operators.BuildFirstCachedJoinDriver
 
buildFlinkTuple(T, HCatRecord) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
buildFlinkTuple(T, HCatRecord) - Method in class org.apache.flink.hcatalog.java.HCatInputFormat
 
buildGraph(ExecutionGraph, JobGraph, Configuration, ScheduledExecutorService, Executor, SlotProvider, ClassLoader, CheckpointRecoveryFactory, Time, RestartStrategy, MetricGroup, int, BlobWriter, Logger) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
Builds the ExecutionGraph from the JobGraph.
buildInitialTable(MutableObjectIterator<BT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Creates the initial hash table.
buildJDBCInputFormat() - Static method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
A builder used to set parameters to the output format's configuration in a fluent way.
buildJDBCOutputFormat() - Static method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
 
buildOrcInputFormat() - Method in class org.apache.flink.orc.OrcTableSource
 
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.
buildSupportsOpenssl() - Static method in class org.apache.hadoop.util.NativeCodeLoader
Returns true only if this build was compiled with support for openssl.
buildSupportsSnappy() - Static method in class org.apache.hadoop.util.NativeCodeLoader
Returns true only if this build was compiled with support for snappy.
buildTableFromSpilledPartition(HashPartition<BT, PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
buildTableWithUniqueKey(MutableObjectIterator<T>) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
buildTopology() - Static method in class org.apache.flink.storm.exclamation.ExclamationTopology
 
buildTopology() - Static method in class org.apache.flink.storm.wordcount.WordCountTopology
 
buildTopology(boolean) - Static method in class org.apache.flink.storm.wordcount.WordCountTopology
 
buildUserCodeClassLoader(List<URL>, List<URL>, ClassLoader) - Static method in class org.apache.flink.client.program.JobWithJars
 
buildVolumes(Option<String>) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Used to build volume specs for mesos.
BulkBlockChannelReader - Interface in org.apache.flink.runtime.io.disk.iomanager
 
BulkFlushBackoffPolicy() - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
 
BulkIterationBase<T> - Class in org.apache.flink.api.common.operators.base
 
BulkIterationBase(UnaryOperatorInformation<T, T>) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase
 
BulkIterationBase(UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase
 
BulkIterationBase.PartialSolutionPlaceHolder<OT> - Class in org.apache.flink.api.common.operators.base
Specialized operator to use as a recognizable place-holder for the input to the step function when composing the nested data flow.
BulkIterationBase.TerminationCriterionAggregationConvergence - Class in org.apache.flink.api.common.operators.base
Convergence for the termination criterion is reached if no tuple is output at current iteration for the termination criterion branch
BulkIterationBase.TerminationCriterionAggregator - Class in org.apache.flink.api.common.operators.base
Aggregator that basically only adds 1 for every output tuple of the termination criterion branch
BulkIterationBase.TerminationCriterionMapper<X> - Class in org.apache.flink.api.common.operators.base
Special Mapper that is added before a termination criterion and is only a container for an special aggregator
BulkIterationNode - Class in org.apache.flink.optimizer.dag
A node in the optimizer's program representation for a bulk iteration.
BulkIterationNode(BulkIterationBase<?>) - Constructor for class org.apache.flink.optimizer.dag.BulkIterationNode
Creates a new node for the bulk iteration.
BulkIterationPlanNode - Class in org.apache.flink.optimizer.plan
 
BulkIterationPlanNode(BulkIterationNode, String, Channel, BulkPartialSolutionPlanNode, PlanNode) - Constructor for class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
BulkIterationPlanNode(BulkIterationNode, String, Channel, BulkPartialSolutionPlanNode, PlanNode, PlanNode) - Constructor for class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
BulkIterationResultSet<T> - Class in org.apache.flink.api.java.operators
Resulting DataSet of bulk iterations.
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 - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
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_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
BYTE_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ByteArrayInputStreamWithPos - Class in org.apache.flink.core.memory
Un-synchronized stream similar to Java's ByteArrayInputStream that also exposes the current position.
ByteArrayInputStreamWithPos(byte[]) - Constructor for class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayInputStreamWithPos(byte[], int, int) - Constructor for class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayOutputStreamWithPos - Class in org.apache.flink.core.memory
Un-synchronized stream similar to Java's ByteArrayOutputStream that also exposes the current position.
ByteArrayOutputStreamWithPos() - Constructor for class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
ByteArrayOutputStreamWithPos(int) - Constructor for class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
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() - Method in class org.apache.flink.runtime.checkpoint.MasterState
 
BYTES_COPIED_CNT_NAME - Static variable in class org.apache.flink.examples.java.distcp.DistCp
 
ByteSerializer - Class in org.apache.flink.api.common.typeutils.base
 
ByteSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
ByteSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
 
BytesSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
 
ByteStreamStateHandle - Class in org.apache.flink.runtime.state.memory
A state handle that contains stream state in a byte array.
ByteStreamStateHandle(String, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
Creates a new ByteStreamStateHandle containing the given data.
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.
ByteValueArray - Class in org.apache.flink.graph.types.valuearray
An array of ByteValue.
ByteValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.ByteValueArray
Initializes an expandable array with default capacity.
ByteValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.ByteValueArray
Initializes a fixed-size array with the provided number of bytes.
ByteValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
Specialized comparator for ByteValueArray based on CopyableValueComparator.
ByteValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.ByteValueArrayComparator
 
ByteValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
Specialized serializer for ByteValueArray.
ByteValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
 
ByteValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for ByteValue based on CopyableValueComparator.
ByteValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
ByteValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a ByteValue.
ByteValueParser() - Constructor for class org.apache.flink.types.parser.ByteValueParser
 
ByteValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
ByteValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
Bzip2InputStreamFactory - Class in org.apache.flink.api.common.io.compression
 
Bzip2InputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 

C

cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
cacheBaseStatistics(BaseStatistics, String) - Method in class org.apache.flink.optimizer.DataStatistics
Caches the given statistics.
cachedPlans - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
cacheFile - Variable in class org.apache.flink.api.common.Plan
Hash map for files in the distributed cache: registered name to cache entry.
cacheFile - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
cachePartitionInfo(PartialInputChannelDeploymentDescriptor) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
calculateHeapSize(int, Configuration) - Static method in class org.apache.flink.yarn.Utils
See documentation.
calculateHeapSizeMB(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of heap memory to use (to set via -Xmx and -Xms) based on the total memory to use and the given configuration parameters.
calculateNetworkBufferMemory(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of memory used for network buffers based on the total memory to use and the according configuration parameters.
calculateNetworkBufferMemory(TaskManagerServicesConfiguration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of memory used for network buffers inside the current JVM instance based on the available heap or the max heap size and the according configuration parameters.
calculatePreferredLocations(LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.Execution
Calculates the preferred locations based on the location preference constraint.
calendar() - Static method in class org.apache.calcite.avatica.util.DateTimeUtils
Creates an instance of Calendar in the root locale and UTC time zone.
call() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
This method implements the strategy for the actual IO operation:
call() - Method in class org.apache.flink.yarn.YarnTaskManagerRunnerFactory.Runner
 
callAsync(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
Execute the callable in the main thread of the underlying RPC endpoint and return a future for the callable result.
CallAsync - Class in org.apache.flink.runtime.rpc.messages
Message for asynchronous callable invocations
CallAsync(Callable<?>) - Constructor for class org.apache.flink.runtime.rpc.messages.CallAsync
 
callAsync(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the callable in the main thread of the underlying RPC service, returning a future for the result of the callable.
callAsyncWithoutFencing(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
callAsyncWithoutFencing(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.FencedMainThreadExecutable
Run the given callable in the main thread without attaching a fencing token.
callAsyncWithoutFencing(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
Run the given callable in the main thread of the RpcEndpoint without checking the fencing token.
callback - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
callback - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
The callback than handles error propagation or logging callbacks.
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeInnerJoinIterator
Calls the JoinFunction#join() method for all two key-value pairs that share the same key and come from different inputs.
callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
Calls the JoinFunction#join() method for all two key-value pairs that share the same key and come from different inputs.
callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeOuterJoinIterator
Calls the JoinFunction#join() method for all two key-value pairs that share the same key and come from different inputs.
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
Moves the internal pointer to the next key that both inputs share.
canBeSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Checks whether this checkpoint can be subsumed or whether it should always continue, regardless of newer checkpoints in progress.
cancel(String[]) - Method in class org.apache.flink.client.CliFrontend
Executes the CANCEL action.
cancel(JobID) - Method in class org.apache.flink.client.program.ClusterClient
Cancels a job identified by the job id.
cancel(JobID) - Method in class org.apache.flink.client.program.rest.RestClusterClient
 
cancel() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Cancels all currently running vertex executions.
cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
cancel(boolean) - Method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
cancel() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
cancel() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
This method is called when a task is canceled either as a result of a user abort or an execution failure.
cancel(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
cancel(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Cancels the currently executed job.
cancel() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.BatchTask
 
cancel() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.CrossDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.DataSinkTask
 
cancel() - Method in class org.apache.flink.runtime.operators.DataSourceTask
 
cancel() - Method in interface org.apache.flink.runtime.operators.Driver
This method is invoked when the driver must aborted in mid processing.
cancel() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.JoinDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.MapDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
cancel() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
Cancels the registration procedure.
cancel(boolean) - Method in class org.apache.flink.runtime.state.DoneFuture
 
cancel() - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
Cancels the source.
cancel() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
Deprecated.
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
cancel() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
Cancels the source.
cancel() - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
cancel() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
cancel() - Method in class org.apache.flink.streaming.api.operators.StreamSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
 
cancel() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
 
cancel() - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteNewDataSource
 
cancel() - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteTrainingDataSource
 
cancel() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
cancelAndReleaseAllSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
cancelChainedTasks(List<ChainedDriver<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
Cancels all tasks via their ChainedDriver.cancelTask() method.
CancelCheckpointMarker - Class in org.apache.flink.runtime.io.network.api
The CancelCheckpointMarker travels through the data streams, similar to the CheckpointBarrier, but signals that a certain checkpoint should be canceled.
CancelCheckpointMarker(long) - Constructor for class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
Cancels any cleanup task that subclasses may be executing.
cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
 
cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.TransientBlobCache
 
cancelExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
Cancels the task execution.
cancelJob(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
cancelJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
cancelJob(JobID, Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
Cancel the given job.
cancelJob(JobID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Cancels the given job.
cancelJobWithSavepoint(JobID, String, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
cancelJobWithSavepoint(JobID, String, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Cancels the given job after taking a savepoint and returning its path.
CancelOptions - Class in org.apache.flink.client.cli
Command line options for the CANCEL command.
CancelOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.CancelOptions
 
cancelStackTraceSample(int, Throwable) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Cancels a pending sample.
cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Registry for all opened streams, so they can be closed if the task using this backend is closed
cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Cancel the given task.
cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Cancel the given task.
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
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
 
cancelWithFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Cancels all currently running vertex executions.
cancelWithSavepoint(JobID, String) - Method in class org.apache.flink.client.program.ClusterClient
Cancels a job identified by the job id and triggers a savepoint.
cancelWithSavepoint(JobID, String) - Method in class org.apache.flink.client.program.rest.RestClusterClient
 
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.SqlTimeTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Returns true if the given object can be equaled with this object.
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
canEqual(Object) - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
Returns true if the given object can be equaled with this object.
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Returns true if the given object can be equaled with this object.
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoField
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
Deprecated.
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
canEqual(Object) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
canEqual(Object) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
canEqual(Object) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
canEqual(Object) - Method in class org.apache.flink.formats.avro.typeutils.AvroSerializer
 
canEqual(Object) - Method in class org.apache.flink.formats.avro.typeutils.BackwardsCompatibleAvroSerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.drivers.transform.LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.ByteValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.CharValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.DoubleValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.FloatValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.ShortValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceSerializer
 
canEqual(Object) - Method in class org.apache.flink.queryablestate.client.VoidNamespaceTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.StateSerializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.ContextStateSerializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.TransactionStateSerializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
Returns true if this trigger supports merging of trigger state and can therefore be used with a MergingWindowAssigner.
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.clustering.TriangleListingBase
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.linkanalysis.PageRank
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
 
canMergeConfigurationWith(GraphAlgorithmWrappingBase) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase
First test whether the algorithm configurations can be merged before the call to GraphAlgorithmWrappingBase.mergeConfiguration(org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingBase).
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.FailureRateRestartStrategy
 
canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
canRestart() - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
True if the restart strategy can be applied to restart the ExecutionGraph.
CAR_DATA - Static variable in class org.apache.flink.streaming.examples.windowing.util.TopSpeedWindowingExampleData
 
CartesianProductDescriptor - Class in org.apache.flink.optimizer.operators
 
CartesianProductDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
CassandraAppendTableSink - Class in org.apache.flink.streaming.connectors.cassandra
An AppendStreamTableSink to write an append stream Table to a Cassandra table.
CassandraAppendTableSink(ClusterBuilder, String) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraAppendTableSink
 
CassandraAppendTableSink(ClusterBuilder, String, Properties) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraAppendTableSink
 
CassandraCommitter - Class in org.apache.flink.streaming.connectors.cassandra
CheckpointCommitter that saves information about completed checkpoints within a separate table in a cassandra database.
CassandraCommitter(ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
 
CassandraCommitter(ClusterBuilder, String) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
 
CassandraInputFormat<OUT extends Tuple> - Class in org.apache.flink.batch.connectors.cassandra
InputFormat to read data from Apache Cassandra and generate $Tuple.
CassandraInputFormat(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
 
CassandraOutputFormat<OUT extends Tuple> - Class in org.apache.flink.batch.connectors.cassandra
OutputFormat to write Tuple into Apache Cassandra.
CassandraOutputFormat(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormat
 
CassandraPojoSink<IN> - Class in org.apache.flink.streaming.connectors.cassandra
Flink Sink to save data into a Cassandra cluster using Mapper, which it uses annotations from com.datastax.driver.mapping.annotations.
CassandraPojoSink(Class<IN>, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
The main constructor for creating CassandraPojoSink.
CassandraPojoSink(Class<IN>, ClusterBuilder, MapperOptions) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
 
CassandraPojoSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraPojoSinkBuilder
 
CassandraRowSink - Class in org.apache.flink.streaming.connectors.cassandra
A SinkFunction to write Row records into a Cassandra table.
CassandraRowSink(int, String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraRowSink
 
CassandraRowSinkBuilder(DataStream<Row>, TypeInformation<Row>, TypeSerializer<Row>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraRowSinkBuilder
 
CassandraRowWriteAheadSink - Class in org.apache.flink.streaming.connectors.cassandra
Sink that emits its input elements into a Cassandra table.
CassandraRowWriteAheadSink(String, TypeSerializer<Row>, ClusterBuilder, CheckpointCommitter) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraRowWriteAheadSink
 
CassandraScalaProductSink<IN extends scala.Product> - Class in org.apache.flink.streaming.connectors.cassandra
Sink to write scala tuples and case classes into a Cassandra cluster.
CassandraScalaProductSink(String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraScalaProductSink
 
CassandraScalaProductSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraScalaProductSinkBuilder
 
CassandraSink<IN> - Class in org.apache.flink.streaming.connectors.cassandra
This class wraps different Cassandra sink implementations to provide a common interface for all of them.
CassandraSink.CassandraPojoSinkBuilder<IN> - Class in org.apache.flink.streaming.connectors.cassandra
Builder for a CassandraPojoSink.
CassandraSink.CassandraRowSinkBuilder - Class in org.apache.flink.streaming.connectors.cassandra
Builder for a CassandraRowSink.
CassandraSink.CassandraScalaProductSinkBuilder<IN extends scala.Product> - Class in org.apache.flink.streaming.connectors.cassandra
CassandraSink.CassandraSinkBuilder<IN> - Class in org.apache.flink.streaming.connectors.cassandra
Builder for a CassandraSink.
CassandraSink.CassandraTupleSinkBuilder<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
Builder for a CassandraTupleSink.
CassandraSinkBase<IN,V> - Class in org.apache.flink.streaming.connectors.cassandra
CassandraSinkBase is the common abstract class of CassandraPojoSink and CassandraTupleSink.
CassandraSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
CassandraTupleSink<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
Sink to write Flink Tuples into a Cassandra cluster.
CassandraTupleSink(String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraTupleSink
 
CassandraTupleSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraTupleSinkBuilder
 
CassandraTupleWriteAheadSink<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
Sink that emits its input elements into a Cassandra database.
CassandraTupleWriteAheadSink(String, TypeSerializer<IN>, ClusterBuilder, CheckpointCommitter) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
 
CCMessenger(TypeInformation<VV>) - 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
 
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
 
CEPOperatorUtils - Class in org.apache.flink.cep.operator
Utility methods for creating PatternStream.
CEPOperatorUtils() - Constructor for class org.apache.flink.cep.operator.CEPOperatorUtils
 
ChainedAllReduceDriver<IT> - Class in org.apache.flink.runtime.operators.chaining
 
ChainedAllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
ChainedDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
The interface to be implemented by drivers that do not run in an own task context, but are chained to other tasks.
ChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
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
 
ChainedReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators.chaining
Chained version of ReduceCombineDriver.
ChainedReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
ChainedStateHandle<T extends StateObject> - Class in org.apache.flink.runtime.state
Handle to state handles for the operators in an operator chain.
ChainedStateHandle(List<? extends T>) - Constructor for class org.apache.flink.runtime.state.ChainedStateHandle
Wraps a list to the state handles for the operators in a chain.
chainedTasks - Variable in class org.apache.flink.runtime.operators.BatchTask
A list of chained drivers, if there are any.
ChainedTerminationCriterionDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
 
ChainedTerminationCriterionDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
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.
Channel - Class in org.apache.flink.optimizer.plan
A Channel represents the result produced by an operator and the data exchange before the consumption by the target operator.
Channel(PlanNode) - Constructor for class org.apache.flink.optimizer.plan.Channel
 
Channel(PlanNode, TempMode) - Constructor for class org.apache.flink.optimizer.plan.Channel
 
channel - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
 
channel - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
channelActive(ChannelHandlerContext) - Method in class org.apache.flink.queryablestate.network.AbstractServerHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.flink.queryablestate.network.AbstractServerHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.flink.queryablestate.network.ClientHandler
 
channelIndex - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.flink.queryablestate.network.AbstractServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.flink.queryablestate.network.ClientHandler
 
channelRead0(ChannelHandlerContext, Object) - Method in class org.apache.flink.mesos.util.MesosArtifactServer.UnknownFileHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.mesos.util.MesosArtifactServer.VirtualFileServerHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.PipelineErrorHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.rest.handler.RedirectHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.webmonitor.history.HistoryServerStaticFileServerHandler
 
channelRead0(ChannelHandlerContext, HttpObject) - Method in class org.apache.flink.runtime.webmonitor.HttpRequestHandler
 
channelRead0(ChannelHandlerContext, Object) - Method in class org.apache.flink.runtime.webmonitor.PipelineErrorHandler
 
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
 
CharacterFilter - Interface in org.apache.flink.metrics
Interface for a character filter function.
charAt(int) - Method in class org.apache.flink.types.StringValue
 
CharComparator - Class in org.apache.flink.api.common.typeutils.base
 
CharComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.CharComparator
 
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.
CharValueArray - Class in org.apache.flink.graph.types.valuearray
An array of CharValue.
CharValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.CharValueArray
Initializes an expandable array with default capacity.
CharValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.CharValueArray
Initializes a fixed-size array with the provided number of chars.
CharValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
Specialized comparator for CharValueArray based on CopyableValueComparator.
CharValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.CharValueArrayComparator