Uses of Class
org.apache.flink.runtime.taskexecutor.KvStateService
-
Packages that use KvStateService Package Description org.apache.flink.runtime.taskexecutor org.apache.flink.runtime.taskmanager -
-
Uses of KvStateService in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return KvStateService Modifier and Type Method Description static KvStateService
KvStateService. fromConfiguration(TaskManagerServicesConfiguration taskManagerServicesConfiguration)
Creates and returns the KvState service.KvStateService
TaskManagerServices. getKvStateService()
-
Uses of KvStateService in org.apache.flink.runtime.taskmanager
Constructors in org.apache.flink.runtime.taskmanager with parameters of type KvStateService Constructor Description 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.
-