Uses of Package
org.apache.flink.runtime.taskexecutor
-
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.execution Class Description GlobalAggregateManager This interface gives access to transient, named, global aggregates. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.io.network.partition Class Description TaskExecutorGateway TaskExecutor
RPC gateway interface. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.jobmanager.slots Class Description TaskExecutorOperatorEventGateway The gateway through which theOperatorCoordinator
can send an event to an Operator on the Task Manager side. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.jobmaster Class Description ExecutionDeploymentReport A report about the currently deployed executions of a TaskExecutor.TaskExecutorGateway TaskExecutor
RPC gateway interface.TaskExecutorOperatorEventGateway The gateway through which theOperatorCoordinator
can send an event to an Operator on the Task Manager side.TaskExecutorToJobManagerHeartbeatPayload Payload for heartbeats sent from the TaskExecutor to the JobManager. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.resourcemanager Class Description FileType Different file types to request from theTaskExecutor
.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.TaskExecutorHeartbeatPayload Payload for heartbeats sent from the TaskExecutor to the ResourceManager.TaskExecutorMemoryConfiguration TaskExecutorConfiguration collects the configuration of a TaskExecutor instance.TaskExecutorThreadInfoGateway RPC gateway for requestingThreadInfoSample
. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.resourcemanager.registration Class Description TaskExecutorGateway TaskExecutor
RPC gateway interface.TaskExecutorMemoryConfiguration TaskExecutorConfiguration collects the configuration of a TaskExecutor instance. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.resourcemanager.slotmanager Class Description 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. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.rest.messages.taskmanager Class Description TaskExecutorMemoryConfiguration TaskExecutorConfiguration collects the configuration of a TaskExecutor instance. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.taskexecutor Class Description AccumulatorReport A report about the current values of all accumulators of the TaskExecutor for a given job.DefaultJobTable Default implementation of theJobTable
.ExecutionDeploymentReport A report about the currently deployed executions of a TaskExecutor.FileType Different file types to request from theTaskExecutor
.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.KvStateService KvState related components of eachTaskExecutor
instance.PartitionProducerStateChecker Intermediate partition state checker to query the JobManager about the state of the producer of a result partition.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.TaskExecutor TaskExecutor implementation.TaskExecutorGateway TaskExecutor
RPC gateway interface.TaskExecutorMemoryConfiguration TaskExecutorConfiguration collects the configuration of a TaskExecutor instance.TaskExecutorOperatorEventGateway The gateway through which theOperatorCoordinator
can send an event to an Operator on the Task Manager side.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
.TaskExecutorThreadInfoGateway RPC gateway for requestingThreadInfoSample
.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.Result TaskManagerRunner.TaskExecutorService TaskManagerRunner.TaskExecutorServiceFactory Factory forTaskExecutor
.TaskManagerServices TaskManagerServicesConfiguration Configuration for the task manager services such as the memory manager, the io manager and the metric registry. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.taskexecutor.rpc Class Description GlobalAggregateManager This interface gives access to transient, named, global aggregates.PartitionProducerStateChecker Intermediate partition state checker to query the JobManager about the state of the producer of a result partition. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.taskexecutor.slot Class Description 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. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.taskmanager Class Description GlobalAggregateManager This interface gives access to transient, named, global aggregates.KvStateService KvState related components of eachTaskExecutor
instance.PartitionProducerStateChecker Intermediate partition state checker to query the JobManager about the state of the producer of a result partition. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.runtime.webmonitor.threadinfo Class Description TaskExecutorThreadInfoGateway RPC gateway for requestingThreadInfoSample
. -
Classes in org.apache.flink.runtime.taskexecutor used by org.apache.flink.streaming.api.operators Class Description GlobalAggregateManager This interface gives access to transient, named, global aggregates.