Package org.apache.flink.runtime.taskexecutor
-
Interface Summary Interface Description GlobalAggregateManager This interface gives access to transient, named, global aggregates.JobLeaderListener Listener for theJobLeaderService
.JobLeaderService This service has the responsibility to monitor the job leaders (the job manager which is leader for a given job) for all registered jobs.JobTable AJobTable's
task is to manage the lifecycle of a job on theTaskExecutor
.JobTable.Connection A connection contains services bound to the lifetime of a connection with a JobManager.JobTable.Job A job contains services which are bound to the lifetime of a Flink job.JobTable.JobServices Services associated with a job.PartitionProducerStateChecker Intermediate partition state checker to query the JobManager about the state of the producer of a result partition.TaskExecutorGateway TaskExecutor
RPC gateway interface.TaskExecutorOperatorEventGateway The gateway through which theOperatorCoordinator
can send an event to an Operator on the Task Manager side.TaskExecutorThreadInfoGateway RPC gateway for requestingThreadInfoSample
.TaskManagerRunner.TaskExecutorService TaskManagerRunner.TaskExecutorServiceFactory Factory forTaskExecutor
. -
Class Summary Class Description AccumulatorReport A report about the current values of all accumulators of the TaskExecutor for a given job.DefaultJobLeaderService Default implementation ofJobLeaderService
.DefaultJobTable Default implementation of theJobTable
.ExecutionDeploymentReport A report about the currently deployed executions of a TaskExecutor.KvStateService KvState related components of eachTaskExecutor
instance.QueryableStateConfiguration Simple configuration object for the parameters for the server-side of queryable state.SlotReport A report about the current status of all slots of the TaskExecutor, describing which slots are available and allocated, and what jobs (JobManagers) the allocated slots have been allocated to.SlotStatus This describes the slot current status which located in TaskManager.SystemOutRedirectionUtils Utility class for redirect theSystem.out
andSystem.err
.TaskExecutor TaskExecutor implementation.TaskExecutorGatewayDecoratorBase A class that decorates/forwards calls to aTaskExecutorGateway
.TaskExecutorHeartbeatPayload Payload for heartbeats sent from the TaskExecutor to the ResourceManager.TaskExecutorMemoryConfiguration TaskExecutorConfiguration collects the configuration of a TaskExecutor instance.TaskExecutorRegistrationRejection Rejection response from theResourceManager
for theTaskExecutor
.TaskExecutorRegistrationSuccess Base class for responses from the ResourceManager to a registration attempt by a TaskExecutor.TaskExecutorResourceSpec Specification of resources to use in runningTaskExecutor
.TaskExecutorResourceUtils Utility class forTaskExecutorResourceSpec
of runningTaskExecutor
.TaskExecutorToJobManagerHeartbeatPayload Payload for heartbeats sent from the TaskExecutor to the JobManager.TaskExecutorToResourceManagerConnection The connection between a TaskExecutor and the ResourceManager.TaskExecutorToServiceAdapter Simple adapter forTaskExecutor
to adapt toTaskManagerRunner.TaskExecutorService
.TaskManagerConfiguration Configuration object forTaskExecutor
.TaskManagerRunner This class is the executable entry point for the task manager in yarn or standalone mode.TaskManagerServices TaskManagerServicesConfiguration Configuration for the task manager services such as the memory manager, the io manager and the metric registry. -
Enum Summary Enum Description FileType Different file types to request from theTaskExecutor
.TaskManagerRunner.Result