Class SavepointEnvironment

  • All Implemented Interfaces:
    org.apache.flink.runtime.execution.Environment

    @Internal
    public class SavepointEnvironment
    extends Object
    implements org.apache.flink.runtime.execution.Environment
    A minimally implemented Environment that provides the functionality required to run the state-processor-api.
    • Method Detail

      • getExecutionConfig

        public org.apache.flink.api.common.ExecutionConfig getExecutionConfig()
        Specified by:
        getExecutionConfig in interface org.apache.flink.runtime.execution.Environment
      • getJobID

        public org.apache.flink.api.common.JobID getJobID()
        Specified by:
        getJobID in interface org.apache.flink.runtime.execution.Environment
      • getJobType

        public org.apache.flink.runtime.jobgraph.JobType getJobType()
        Specified by:
        getJobType in interface org.apache.flink.runtime.execution.Environment
      • getJobVertexId

        public org.apache.flink.runtime.jobgraph.JobVertexID getJobVertexId()
        Specified by:
        getJobVertexId in interface org.apache.flink.runtime.execution.Environment
      • getExecutionId

        public org.apache.flink.runtime.executiongraph.ExecutionAttemptID getExecutionId()
        Specified by:
        getExecutionId in interface org.apache.flink.runtime.execution.Environment
      • getTaskConfiguration

        public org.apache.flink.configuration.Configuration getTaskConfiguration()
        Specified by:
        getTaskConfiguration in interface org.apache.flink.runtime.execution.Environment
      • getTaskManagerInfo

        public org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo getTaskManagerInfo()
        Specified by:
        getTaskManagerInfo in interface org.apache.flink.runtime.execution.Environment
      • getMetricGroup

        public org.apache.flink.runtime.metrics.groups.TaskMetricGroup getMetricGroup()
        Specified by:
        getMetricGroup in interface org.apache.flink.runtime.execution.Environment
      • getJobConfiguration

        public org.apache.flink.configuration.Configuration getJobConfiguration()
        Specified by:
        getJobConfiguration in interface org.apache.flink.runtime.execution.Environment
      • getJobInfo

        public org.apache.flink.api.common.JobInfo getJobInfo()
        Specified by:
        getJobInfo in interface org.apache.flink.runtime.execution.Environment
      • getTaskInfo

        public org.apache.flink.api.common.TaskInfo getTaskInfo()
        Specified by:
        getTaskInfo in interface org.apache.flink.runtime.execution.Environment
      • getInputSplitProvider

        public org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider getInputSplitProvider()
        Specified by:
        getInputSplitProvider in interface org.apache.flink.runtime.execution.Environment
      • getIOManager

        public org.apache.flink.runtime.io.disk.iomanager.IOManager getIOManager()
        Specified by:
        getIOManager in interface org.apache.flink.runtime.execution.Environment
      • getMemoryManager

        public org.apache.flink.runtime.memory.MemoryManager getMemoryManager()
        Specified by:
        getMemoryManager in interface org.apache.flink.runtime.execution.Environment
      • getSharedResources

        public org.apache.flink.runtime.memory.SharedResources getSharedResources()
        Specified by:
        getSharedResources in interface org.apache.flink.runtime.execution.Environment
      • getUserCodeClassLoader

        public org.apache.flink.util.UserCodeClassLoader getUserCodeClassLoader()
        Specified by:
        getUserCodeClassLoader in interface org.apache.flink.runtime.execution.Environment
      • getDistributedCacheEntries

        public Map<String,​Future<org.apache.flink.core.fs.Path>> getDistributedCacheEntries()
        Specified by:
        getDistributedCacheEntries in interface org.apache.flink.runtime.execution.Environment
      • getBroadcastVariableManager

        public org.apache.flink.runtime.broadcast.BroadcastVariableManager getBroadcastVariableManager()
        Specified by:
        getBroadcastVariableManager in interface org.apache.flink.runtime.execution.Environment
      • getTaskStateManager

        public org.apache.flink.runtime.state.TaskStateManager getTaskStateManager()
        Specified by:
        getTaskStateManager in interface org.apache.flink.runtime.execution.Environment
      • getGlobalAggregateManager

        public org.apache.flink.runtime.taskexecutor.GlobalAggregateManager getGlobalAggregateManager()
        Specified by:
        getGlobalAggregateManager in interface org.apache.flink.runtime.execution.Environment
      • getExternalResourceInfoProvider

        public org.apache.flink.runtime.externalresource.ExternalResourceInfoProvider getExternalResourceInfoProvider()
        Specified by:
        getExternalResourceInfoProvider in interface org.apache.flink.runtime.execution.Environment
      • getAccumulatorRegistry

        public org.apache.flink.runtime.accumulators.AccumulatorRegistry getAccumulatorRegistry()
        Specified by:
        getAccumulatorRegistry in interface org.apache.flink.runtime.execution.Environment
      • getTaskKvStateRegistry

        public org.apache.flink.runtime.query.TaskKvStateRegistry getTaskKvStateRegistry()
        Specified by:
        getTaskKvStateRegistry in interface org.apache.flink.runtime.execution.Environment
      • acknowledgeCheckpoint

        public void acknowledgeCheckpoint​(long checkpointId,
                                          org.apache.flink.runtime.checkpoint.CheckpointMetrics checkpointMetrics)
        Specified by:
        acknowledgeCheckpoint in interface org.apache.flink.runtime.execution.Environment
      • acknowledgeCheckpoint

        public void acknowledgeCheckpoint​(long checkpointId,
                                          org.apache.flink.runtime.checkpoint.CheckpointMetrics checkpointMetrics,
                                          org.apache.flink.runtime.checkpoint.TaskStateSnapshot subtaskState)
        Specified by:
        acknowledgeCheckpoint in interface org.apache.flink.runtime.execution.Environment
      • declineCheckpoint

        public void declineCheckpoint​(long checkpointId,
                                      org.apache.flink.runtime.checkpoint.CheckpointException checkpointException)
        Specified by:
        declineCheckpoint in interface org.apache.flink.runtime.execution.Environment
      • getOperatorCoordinatorEventGateway

        public org.apache.flink.runtime.jobgraph.tasks.TaskOperatorEventGateway getOperatorCoordinatorEventGateway()
        Specified by:
        getOperatorCoordinatorEventGateway in interface org.apache.flink.runtime.execution.Environment
      • failExternally

        public void failExternally​(Throwable cause)
        Specified by:
        failExternally in interface org.apache.flink.runtime.execution.Environment
      • getWriter

        public org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter getWriter​(int index)
        Specified by:
        getWriter in interface org.apache.flink.runtime.execution.Environment
      • getAllWriters

        public org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter[] getAllWriters()
        Specified by:
        getAllWriters in interface org.apache.flink.runtime.execution.Environment
      • getInputGate

        public org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate getInputGate​(int index)
        Specified by:
        getInputGate in interface org.apache.flink.runtime.execution.Environment
      • getAllInputGates

        public org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate[] getAllInputGates()
        Specified by:
        getAllInputGates in interface org.apache.flink.runtime.execution.Environment
      • getTaskEventDispatcher

        public org.apache.flink.runtime.io.network.TaskEventDispatcher getTaskEventDispatcher()
        Specified by:
        getTaskEventDispatcher in interface org.apache.flink.runtime.execution.Environment
      • getChannelStateExecutorFactory

        public org.apache.flink.runtime.checkpoint.channel.ChannelStateWriteRequestExecutorFactory getChannelStateExecutorFactory()
        Specified by:
        getChannelStateExecutorFactory in interface org.apache.flink.runtime.execution.Environment
      • getTaskManagerActions

        public org.apache.flink.runtime.taskmanager.TaskManagerActions getTaskManagerActions()
        Specified by:
        getTaskManagerActions in interface org.apache.flink.runtime.execution.Environment