Uses of Interface
org.apache.flink.runtime.execution.Environment
-
-
Uses of Environment in org.apache.flink.runtime.checkpoint.filemerging
Methods in org.apache.flink.runtime.checkpoint.filemerging with parameters of type Environment Modifier and Type Method Description static FileMergingSnapshotManager.SubtaskKey
FileMergingSnapshotManager.SubtaskKey. of(Environment environment)
-
Uses of Environment in org.apache.flink.runtime.iterative.task
Constructors in org.apache.flink.runtime.iterative.task with parameters of type Environment Constructor Description AbstractIterativeTask(Environment environment)
Create an Invokable task and set its environment.IterationHeadTask(Environment environment)
Create an Invokable task and set its environment.IterationIntermediateTask(Environment environment)
Create an Invokable task and set its environment.IterationSynchronizationSinkTask(Environment environment)
Create an Invokable task and set its environment.IterationTailTask(Environment environment)
Create an Invokable task and set its environment. -
Uses of Environment in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks that return Environment Modifier and Type Method Description Environment
AbstractInvokable. getEnvironment()
Returns the environment of this task.Constructors in org.apache.flink.runtime.jobgraph.tasks with parameters of type Environment Constructor Description AbstractInvokable(Environment environment)
Create an Invokable task and set its environment. -
Uses of Environment in org.apache.flink.runtime.operators
Constructors in org.apache.flink.runtime.operators with parameters of type Environment Constructor Description BatchTask(Environment environment)
Create an Invokable task and set its environment.DataSinkTask(Environment environment)
Create an Invokable task and set its environment.DataSourceTask(Environment environment)
Create an Invokable task and set its environment. -
Uses of Environment in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return Environment Modifier and Type Method Description Environment
KeyedStateBackendParametersImpl. getEnv()
Environment
OperatorStateBackendParametersImpl. getEnv()
Environment
StateBackend.KeyedStateBackendParameters. getEnv()
Environment
StateBackend.OperatorStateBackendParameters. getEnv()
Methods in org.apache.flink.runtime.state with parameters of type Environment Modifier and Type Method Description default CheckpointStorageWorkerView
CheckpointStorageWorkerView. toFileMergingStorage(FileMergingSnapshotManager mergingSnapshotManager, Environment environment)
ReturnFsMergingCheckpointStorageAccess
if file merging is enabled.Constructors in org.apache.flink.runtime.state with parameters of type Environment Constructor Description KeyedStateBackendParametersImpl(Environment env, org.apache.flink.api.common.JobID jobID, String operatorIdentifier, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, int numberOfKeyGroups, KeyGroupRange keyGroupRange, TaskKvStateRegistry kvStateRegistry, TtlTimeProvider ttlTimeProvider, org.apache.flink.metrics.MetricGroup metricGroup, Collection<KeyedStateHandle> stateHandles, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
KeyedStateBackendParametersImpl(Environment env, org.apache.flink.api.common.JobID jobID, String operatorIdentifier, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, int numberOfKeyGroups, KeyGroupRange keyGroupRange, TaskKvStateRegistry kvStateRegistry, TtlTimeProvider ttlTimeProvider, org.apache.flink.metrics.MetricGroup metricGroup, StateBackend.CustomInitializationMetrics customInitializationMetrics, Collection<KeyedStateHandle> stateHandles, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry, double managedMemoryFraction)
OperatorStateBackendParametersImpl(Environment env, String operatorIdentifier, Collection<OperatorStateHandle> stateHandles, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
OperatorStateBackendParametersImpl(Environment env, String operatorIdentifier, Collection<OperatorStateHandle> stateHandles, StateBackend.CustomInitializationMetrics customInitializationMetrics, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
-
Uses of Environment in org.apache.flink.runtime.state.filesystem
Methods in org.apache.flink.runtime.state.filesystem with parameters of type Environment Modifier and Type Method Description FsMergingCheckpointStorageAccess
FsCheckpointStorageAccess. toFileMergingStorage(FileMergingSnapshotManager mergingSnapshotManager, Environment environment)
Constructors in org.apache.flink.runtime.state.filesystem with parameters of type Environment Constructor Description FsMergingCheckpointStorageAccess(org.apache.flink.core.fs.Path checkpointBaseDirectory, org.apache.flink.core.fs.Path defaultSavepointDirectory, org.apache.flink.api.common.JobID jobId, int fileSizeThreshold, int writeBufferSize, FileMergingSnapshotManager fileMergingSnapshotManager, Environment environment)
-
Uses of Environment in org.apache.flink.runtime.taskmanager
Classes in org.apache.flink.runtime.taskmanager that implement Environment Modifier and Type Class Description class
RuntimeEnvironment
In implementation of theEnvironment
. -
Uses of Environment in org.apache.flink.streaming.api.operators
Constructors in org.apache.flink.streaming.api.operators with parameters of type Environment Constructor Description StreamingRuntimeContext(Environment env, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> accumulators, org.apache.flink.metrics.groups.OperatorMetricGroup operatorMetricGroup, OperatorID operatorID, ProcessingTimeService processingTimeService, org.apache.flink.api.common.state.KeyedStateStore keyedStateStore, ExternalResourceInfoProvider externalResourceInfoProvider)
StreamingRuntimeContext(AbstractStreamOperator<?> operator, Environment env, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> accumulators)
StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend)
StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend, SubTaskInitializationMetricsBuilder initializationMetrics, TtlTimeProvider ttlTimeProvider, InternalTimeServiceManager.Provider timeServiceManagerProvider, StreamTaskCancellationContext cancellationContext)
-
Uses of Environment in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks that return Environment Modifier and Type Method Description Environment
StreamTask. getEnvironment()
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type Environment Modifier and Type Method Description static <OUT> RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>
StreamTask. createRecordWriterDelegate(StreamConfig configuration, Environment environment)
Constructors in org.apache.flink.streaming.runtime.tasks with parameters of type Environment Constructor Description AbstractTwoInputStreamTask(Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).MultipleInputStreamTask(Environment env)
OneInputStreamTask(Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).OneInputStreamTask(Environment env, TimerService timeProvider)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).SourceOperatorStreamTask(Environment env)
SourceStreamTask(Environment env)
Deprecated.StreamIterationHead(Environment env)
StreamIterationTail(Environment environment)
StreamTask(Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).StreamTask(Environment env, TimerService timerService)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).StreamTask(Environment environment, TimerService timerService, Thread.UncaughtExceptionHandler uncaughtExceptionHandler)
StreamTask(Environment environment, TimerService timerService, Thread.UncaughtExceptionHandler uncaughtExceptionHandler, StreamTaskActionExecutor actionExecutor)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).StreamTask(Environment environment, TimerService timerService, Thread.UncaughtExceptionHandler uncaughtExceptionHandler, StreamTaskActionExecutor actionExecutor, TaskMailbox mailbox)
TwoInputStreamTask(Environment env)
-