Uses of Class
org.apache.flink.runtime.checkpoint.channel.ChannelStateWriteRequestExecutorFactory
-
-
Uses of ChannelStateWriteRequestExecutorFactory in org.apache.flink.runtime.checkpoint.channel
Constructors in org.apache.flink.runtime.checkpoint.channel with parameters of type ChannelStateWriteRequestExecutorFactory Constructor Description ChannelStateWriterImpl(JobVertexID jobVertexID, String taskName, int subtaskIndex, SupplierWithException<CheckpointStorageWorkerView,? extends IOException> checkpointStorageWorkerViewSupplier, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory, int maxSubtasksPerChannelStateFile)
-
Uses of ChannelStateWriteRequestExecutorFactory in org.apache.flink.runtime.execution
Methods in org.apache.flink.runtime.execution that return ChannelStateWriteRequestExecutorFactory Modifier and Type Method Description ChannelStateWriteRequestExecutorFactory
Environment. getChannelStateExecutorFactory()
-
Uses of ChannelStateWriteRequestExecutorFactory in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return ChannelStateWriteRequestExecutorFactory Modifier and Type Method Description ChannelStateWriteRequestExecutorFactory
TaskExecutorChannelStateExecutorFactoryManager. getFactoryByJobId(JobID jobId)
ChannelStateWriteRequestExecutorFactory
TaskExecutorChannelStateExecutorFactoryManager. getOrCreateExecutorFactory(JobID jobID)
-
Uses of ChannelStateWriteRequestExecutorFactory in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager that return ChannelStateWriteRequestExecutorFactory Modifier and Type Method Description ChannelStateWriteRequestExecutorFactory
RuntimeEnvironment. getChannelStateExecutorFactory()
Constructors in org.apache.flink.runtime.taskmanager with parameters of type ChannelStateWriteRequestExecutorFactory Constructor Description RuntimeEnvironment(JobID jobId, JobType jobType, JobVertexID jobVertexId, ExecutionAttemptID executionId, ExecutionConfig executionConfig, JobInfo jobInfo, TaskInfo taskInfo, Configuration jobConfiguration, Configuration taskConfiguration, UserCodeClassLoader userCodeClassLoader, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, BroadcastVariableManager bcVarManager, TaskStateManager taskStateManager, GlobalAggregateManager aggregateManager, AccumulatorRegistry accumulatorRegistry, TaskKvStateRegistry kvStateRegistry, InputSplitProvider splitProvider, Map<String,Future<Path>> distCacheEntries, ResultPartitionWriter[] writers, IndexedInputGate[] inputGates, TaskEventDispatcher taskEventDispatcher, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorEventGateway, TaskManagerRuntimeInfo taskManagerInfo, TaskMetricGroup metrics, Task containingTask, ExternalResourceInfoProvider externalResourceInfoProvider, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory, TaskManagerActions taskManagerActions)
Task(JobInformation jobInformation, TaskInformation taskInformation, ExecutionAttemptID executionAttemptID, AllocationID slotAllocationId, List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors, List<InputGateDeploymentDescriptor> inputGateDeploymentDescriptors, MemoryManager memManager, SharedResources sharedResources, IOManager ioManager, ShuffleEnvironment<?,?> shuffleEnvironment, KvStateService kvStateService, BroadcastVariableManager bcVarManager, TaskEventDispatcher taskEventDispatcher, ExternalResourceInfoProvider externalResourceInfoProvider, TaskStateManager taskStateManager, TaskManagerActions taskManagerActions, InputSplitProvider inputSplitProvider, CheckpointResponder checkpointResponder, TaskOperatorEventGateway operatorCoordinatorEventGateway, GlobalAggregateManager aggregateManager, LibraryCacheManager.ClassLoaderHandle classLoaderHandle, FileCache fileCache, TaskManagerRuntimeInfo taskManagerConfig, TaskMetricGroup metricGroup, PartitionProducerStateChecker partitionProducerStateChecker, Executor executor, ChannelStateWriteRequestExecutorFactory channelStateExecutorFactory)
IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment. -
Uses of ChannelStateWriteRequestExecutorFactory in org.apache.flink.state.api.runtime
Methods in org.apache.flink.state.api.runtime that return ChannelStateWriteRequestExecutorFactory Modifier and Type Method Description ChannelStateWriteRequestExecutorFactory
SavepointEnvironment. getChannelStateExecutorFactory()
-