Class SavepointEnvironment
- java.lang.Object
-
- org.apache.flink.state.api.runtime.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 implementedEnvironment
that provides the functionality required to run thestate-processor-api
.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
SavepointEnvironment.Builder
SavepointEnvironment
builder.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
acknowledgeCheckpoint(long checkpointId, org.apache.flink.runtime.checkpoint.CheckpointMetrics checkpointMetrics)
void
acknowledgeCheckpoint(long checkpointId, org.apache.flink.runtime.checkpoint.CheckpointMetrics checkpointMetrics, org.apache.flink.runtime.checkpoint.TaskStateSnapshot subtaskState)
void
declineCheckpoint(long checkpointId, org.apache.flink.runtime.checkpoint.CheckpointException checkpointException)
void
failExternally(Throwable cause)
org.apache.flink.runtime.accumulators.AccumulatorRegistry
getAccumulatorRegistry()
org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate[]
getAllInputGates()
org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter[]
getAllWriters()
org.apache.flink.runtime.broadcast.BroadcastVariableManager
getBroadcastVariableManager()
org.apache.flink.runtime.checkpoint.channel.ChannelStateWriteRequestExecutorFactory
getChannelStateExecutorFactory()
Map<String,Future<org.apache.flink.core.fs.Path>>
getDistributedCacheEntries()
org.apache.flink.api.common.ExecutionConfig
getExecutionConfig()
org.apache.flink.runtime.executiongraph.ExecutionAttemptID
getExecutionId()
org.apache.flink.runtime.externalresource.ExternalResourceInfoProvider
getExternalResourceInfoProvider()
org.apache.flink.runtime.taskexecutor.GlobalAggregateManager
getGlobalAggregateManager()
org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
getInputGate(int index)
org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider
getInputSplitProvider()
org.apache.flink.runtime.io.disk.iomanager.IOManager
getIOManager()
org.apache.flink.configuration.Configuration
getJobConfiguration()
org.apache.flink.api.common.JobID
getJobID()
org.apache.flink.api.common.JobInfo
getJobInfo()
org.apache.flink.runtime.jobgraph.JobType
getJobType()
org.apache.flink.runtime.jobgraph.JobVertexID
getJobVertexId()
org.apache.flink.runtime.memory.MemoryManager
getMemoryManager()
org.apache.flink.runtime.metrics.groups.TaskMetricGroup
getMetricGroup()
org.apache.flink.runtime.jobgraph.tasks.TaskOperatorEventGateway
getOperatorCoordinatorEventGateway()
org.apache.flink.runtime.memory.SharedResources
getSharedResources()
org.apache.flink.configuration.Configuration
getTaskConfiguration()
org.apache.flink.runtime.io.network.TaskEventDispatcher
getTaskEventDispatcher()
org.apache.flink.api.common.TaskInfo
getTaskInfo()
org.apache.flink.runtime.query.TaskKvStateRegistry
getTaskKvStateRegistry()
org.apache.flink.runtime.taskmanager.TaskManagerActions
getTaskManagerActions()
org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
getTaskManagerInfo()
org.apache.flink.runtime.state.TaskStateManager
getTaskStateManager()
org.apache.flink.util.UserCodeClassLoader
getUserCodeClassLoader()
org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
getWriter(int index)
-
-
-
Method Detail
-
getExecutionConfig
public org.apache.flink.api.common.ExecutionConfig getExecutionConfig()
- Specified by:
getExecutionConfig
in interfaceorg.apache.flink.runtime.execution.Environment
-
getJobID
public org.apache.flink.api.common.JobID getJobID()
- Specified by:
getJobID
in interfaceorg.apache.flink.runtime.execution.Environment
-
getJobType
public org.apache.flink.runtime.jobgraph.JobType getJobType()
- Specified by:
getJobType
in interfaceorg.apache.flink.runtime.execution.Environment
-
getJobVertexId
public org.apache.flink.runtime.jobgraph.JobVertexID getJobVertexId()
- Specified by:
getJobVertexId
in interfaceorg.apache.flink.runtime.execution.Environment
-
getExecutionId
public org.apache.flink.runtime.executiongraph.ExecutionAttemptID getExecutionId()
- Specified by:
getExecutionId
in interfaceorg.apache.flink.runtime.execution.Environment
-
getTaskConfiguration
public org.apache.flink.configuration.Configuration getTaskConfiguration()
- Specified by:
getTaskConfiguration
in interfaceorg.apache.flink.runtime.execution.Environment
-
getTaskManagerInfo
public org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo getTaskManagerInfo()
- Specified by:
getTaskManagerInfo
in interfaceorg.apache.flink.runtime.execution.Environment
-
getMetricGroup
public org.apache.flink.runtime.metrics.groups.TaskMetricGroup getMetricGroup()
- Specified by:
getMetricGroup
in interfaceorg.apache.flink.runtime.execution.Environment
-
getJobConfiguration
public org.apache.flink.configuration.Configuration getJobConfiguration()
- Specified by:
getJobConfiguration
in interfaceorg.apache.flink.runtime.execution.Environment
-
getJobInfo
public org.apache.flink.api.common.JobInfo getJobInfo()
- Specified by:
getJobInfo
in interfaceorg.apache.flink.runtime.execution.Environment
-
getTaskInfo
public org.apache.flink.api.common.TaskInfo getTaskInfo()
- Specified by:
getTaskInfo
in interfaceorg.apache.flink.runtime.execution.Environment
-
getInputSplitProvider
public org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider getInputSplitProvider()
- Specified by:
getInputSplitProvider
in interfaceorg.apache.flink.runtime.execution.Environment
-
getIOManager
public org.apache.flink.runtime.io.disk.iomanager.IOManager getIOManager()
- Specified by:
getIOManager
in interfaceorg.apache.flink.runtime.execution.Environment
-
getMemoryManager
public org.apache.flink.runtime.memory.MemoryManager getMemoryManager()
- Specified by:
getMemoryManager
in interfaceorg.apache.flink.runtime.execution.Environment
-
getSharedResources
public org.apache.flink.runtime.memory.SharedResources getSharedResources()
- Specified by:
getSharedResources
in interfaceorg.apache.flink.runtime.execution.Environment
-
getUserCodeClassLoader
public org.apache.flink.util.UserCodeClassLoader getUserCodeClassLoader()
- Specified by:
getUserCodeClassLoader
in interfaceorg.apache.flink.runtime.execution.Environment
-
getDistributedCacheEntries
public Map<String,Future<org.apache.flink.core.fs.Path>> getDistributedCacheEntries()
- Specified by:
getDistributedCacheEntries
in interfaceorg.apache.flink.runtime.execution.Environment
-
getBroadcastVariableManager
public org.apache.flink.runtime.broadcast.BroadcastVariableManager getBroadcastVariableManager()
- Specified by:
getBroadcastVariableManager
in interfaceorg.apache.flink.runtime.execution.Environment
-
getTaskStateManager
public org.apache.flink.runtime.state.TaskStateManager getTaskStateManager()
- Specified by:
getTaskStateManager
in interfaceorg.apache.flink.runtime.execution.Environment
-
getGlobalAggregateManager
public org.apache.flink.runtime.taskexecutor.GlobalAggregateManager getGlobalAggregateManager()
- Specified by:
getGlobalAggregateManager
in interfaceorg.apache.flink.runtime.execution.Environment
-
getExternalResourceInfoProvider
public org.apache.flink.runtime.externalresource.ExternalResourceInfoProvider getExternalResourceInfoProvider()
- Specified by:
getExternalResourceInfoProvider
in interfaceorg.apache.flink.runtime.execution.Environment
-
getAccumulatorRegistry
public org.apache.flink.runtime.accumulators.AccumulatorRegistry getAccumulatorRegistry()
- Specified by:
getAccumulatorRegistry
in interfaceorg.apache.flink.runtime.execution.Environment
-
getTaskKvStateRegistry
public org.apache.flink.runtime.query.TaskKvStateRegistry getTaskKvStateRegistry()
- Specified by:
getTaskKvStateRegistry
in interfaceorg.apache.flink.runtime.execution.Environment
-
acknowledgeCheckpoint
public void acknowledgeCheckpoint(long checkpointId, org.apache.flink.runtime.checkpoint.CheckpointMetrics checkpointMetrics)
- Specified by:
acknowledgeCheckpoint
in interfaceorg.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 interfaceorg.apache.flink.runtime.execution.Environment
-
declineCheckpoint
public void declineCheckpoint(long checkpointId, org.apache.flink.runtime.checkpoint.CheckpointException checkpointException)
- Specified by:
declineCheckpoint
in interfaceorg.apache.flink.runtime.execution.Environment
-
getOperatorCoordinatorEventGateway
public org.apache.flink.runtime.jobgraph.tasks.TaskOperatorEventGateway getOperatorCoordinatorEventGateway()
- Specified by:
getOperatorCoordinatorEventGateway
in interfaceorg.apache.flink.runtime.execution.Environment
-
failExternally
public void failExternally(Throwable cause)
- Specified by:
failExternally
in interfaceorg.apache.flink.runtime.execution.Environment
-
getWriter
public org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter getWriter(int index)
- Specified by:
getWriter
in interfaceorg.apache.flink.runtime.execution.Environment
-
getAllWriters
public org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter[] getAllWriters()
- Specified by:
getAllWriters
in interfaceorg.apache.flink.runtime.execution.Environment
-
getInputGate
public org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate getInputGate(int index)
- Specified by:
getInputGate
in interfaceorg.apache.flink.runtime.execution.Environment
-
getAllInputGates
public org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate[] getAllInputGates()
- Specified by:
getAllInputGates
in interfaceorg.apache.flink.runtime.execution.Environment
-
getTaskEventDispatcher
public org.apache.flink.runtime.io.network.TaskEventDispatcher getTaskEventDispatcher()
- Specified by:
getTaskEventDispatcher
in interfaceorg.apache.flink.runtime.execution.Environment
-
getChannelStateExecutorFactory
public org.apache.flink.runtime.checkpoint.channel.ChannelStateWriteRequestExecutorFactory getChannelStateExecutorFactory()
- Specified by:
getChannelStateExecutorFactory
in interfaceorg.apache.flink.runtime.execution.Environment
-
getTaskManagerActions
public org.apache.flink.runtime.taskmanager.TaskManagerActions getTaskManagerActions()
- Specified by:
getTaskManagerActions
in interfaceorg.apache.flink.runtime.execution.Environment
-
-