org.apache.flink.api.common.JobID jobID
ExecutionAttemptID executionAttemptID
org.apache.flink.util.SerializedValue<T> userAccumulators
byte[] key
org.apache.flink.runtime.blob.BlobKey.BlobType type
org.apache.flink.util.AbstractID random
long checkpointId
long triggerTimestamp
Map<K,V> taskStats
TaskStateStats
accessible by their ID.int numberOfSubtasks
CheckpointProperties props
CheckpointFailureReason checkpointFailureReason
long checkpointId
long timestamp
long bytesBufferedInAlignment
long alignmentDurationNanos
long syncDurationMillis
long asyncDurationMillis
CheckpointType checkpointType
CheckpointStorageLocationReference targetLocation
CheckpointType checkpointType
boolean forced
boolean discardSubsumed
boolean discardFinished
boolean discardCancelled
boolean discardFailed
boolean discardSuspended
long numRestoredCheckpoints
long numTotalCheckpoints
int numInProgressCheckpoints
long numCompletedCheckpoints
long numFailedCheckpoints
List<E> checkpointsHistory
CheckpointStatsHistory.createSnapshot()
.Map<K,V> checkpointsById
CheckpointStatsHistory.createSnapshot()
.int maxSize
boolean readOnly
CompletedCheckpointStats latestCompletedCheckpoint
FailedCheckpointStats latestFailedCheckpoint
CompletedCheckpointStats latestSavepoint
CheckpointStatsCounts counts
CompletedCheckpointStatsSummary summary
CheckpointStatsHistory history
RestoredCheckpointStats latestRestoredCheckpoint
org.apache.flink.api.common.JobID job
long checkpointID
long timestamp
long duration
Map<K,V> operatorStates
CheckpointProperties props
Collection<E> masterHookStates
CompletedCheckpointStorageLocation storageLocation
StreamStateHandle metadataHandle
String externalPointer
long stateSize
long alignmentBuffered
SubtaskStateStats latestAcknowledgedSubtask
String externalPointer
boolean discarded
MinMaxAvgStats stateSize
MinMaxAvgStats duration
MinMaxAvgStats alignmentBuffered
int numAcknowledgedSubtasks
long stateSize
long alignmentBuffered
long failureTimestamp
SubtaskStateStats latestAcknowledgedSubtask
String failureMsg
long restoreCheckpointId
TaskStateSnapshot taskStateSnapshot
String name
byte[] bytes
int version
long min
long max
long sum
long count
OperatorID operatorID
Map<K,V> operatorSubtaskStates
int parallelism
int maxParallelism
StateObjectCollection<T extends StateObject> managedOperatorState
OperatorStateBackend
.StateObjectCollection<T extends StateObject> rawOperatorState
OperatorStateCheckpointOutputStream
.StateObjectCollection<T extends StateObject> managedKeyedState
KeyedStateBackend
.StateObjectCollection<T extends StateObject> rawKeyedState
KeyedStateCheckpointOutputStream
.long stateSize
int currentNumAcknowledgedSubtasks
long currentStateSize
long currentAlignmentBuffered
SubtaskStateStats latestAcknowledgedSubtask
long checkpointId
CheckpointProperties props
long restoreTimestamp
String externalPath
Collection<E> stateObjects
ChainedStateHandle<T extends StateObject> managedOperatorState
OperatorStateBackend
.ChainedStateHandle<T extends StateObject> rawOperatorState
OperatorStateCheckpointOutputStream
.KeyedStateHandle managedKeyedState
KeyedStateBackend
.KeyedStateHandle rawKeyedState
KeyedStateCheckpointOutputStream
.long stateSize
int subtaskIndex
long ackTimestamp
long stateSize
long syncCheckpointDuration
long asyncCheckpointDuration
long alignmentBuffered
long alignmentDuration
JobVertexID jobVertexID
Map<K,V> subtaskStates
int parallelism
int maxParallelism
int chainLength
JobVertexID jobVertexId
SubtaskStateStats[] subtaskStats
TaskStateStats.TaskStateStatsSummary summaryStats
int numAcknowledgedSubtasks
SubtaskStateStats latestAckedSubtaskStats
MinMaxAvgStats stateSize
MinMaxAvgStats ackTimestamp
MinMaxAvgStats syncCheckpointDuration
MinMaxAvgStats asyncCheckpointDuration
MinMaxAvgStats alignmentBuffered
MinMaxAvgStats alignmentDuration
org.apache.flink.api.common.JobID jobID
org.apache.flink.api.common.JobID jobId
String jobName
org.apache.flink.api.common.JobStatus jobState
long startTime
int numSlots
HashMap<K,V> taskManagerEnv
TaskExecutorProcessSpec taskExecutorProcessSpec
org.apache.flink.api.common.resources.CPUResource cpuCores
org.apache.flink.configuration.MemorySize frameworkHeapSize
org.apache.flink.configuration.MemorySize frameworkOffHeapMemorySize
org.apache.flink.configuration.MemorySize taskHeapSize
org.apache.flink.configuration.MemorySize taskOffHeapSize
org.apache.flink.configuration.MemorySize networkMemSize
org.apache.flink.configuration.MemorySize managedMemorySize
org.apache.flink.configuration.MemorySize jvmMetaspaceSize
org.apache.flink.configuration.MemorySize jvmOverheadSize
String resourceId
private Object readResolve()
org.apache.flink.api.common.resources.Resource cpuCores
org.apache.flink.configuration.MemorySize taskHeapMemory
org.apache.flink.configuration.MemorySize taskOffHeapMemory
org.apache.flink.configuration.MemorySize managedMemory
org.apache.flink.configuration.MemorySize networkMemory
Map<K,V> extendedResources
ResourceSpec
.ResourceID resourceId
int slotNumber
IntermediateDataSetID consumedResultId
ResultPartitionType consumedPartitionType
int consumedSubpartitionIndex
DistributionPattern
and the subtask indices of the producing and consuming task.ShuffleDescriptor[] inputChannels
PartitionDescriptor partitionDescriptor
ShuffleDescriptor shuffleDescriptor
int maxParallelism
boolean sendScheduleOrUpdateConsumersMessage
TaskDeploymentDescriptor.MaybeOffloaded<T> serializedJobInformation
TaskDeploymentDescriptor.MaybeOffloaded<T> serializedTaskInformation
org.apache.flink.api.common.JobID jobId
NOTE: this is redundant to the information stored in TaskDeploymentDescriptor.serializedJobInformation
but
needed in order to restore offloaded data.
ExecutionAttemptID executionId
AllocationID allocationId
int subtaskIndex
int attemptNumber
Collection<E> producedPartitions
Collection<E> inputGates
int targetSlotNumber
JobManagerTaskRestore taskRestore
org.apache.flink.util.SerializedValue<T> serializedValue
PermanentBlobKey serializedValueKey
String blobServerHostname
int blobServerPort
ExecutionAttemptID attemptId
long[] stateTimestamps
int attemptNumber
ExecutionState state
String failureCause
TaskManagerLocation assignedResourceLocation
AllocationID assignedAllocationID
StringifiedAccumulatorResult[] userAccumulators
int parallelSubtaskIndex
IOMetrics ioMetrics
org.apache.flink.api.common.JobID jobID
String jobName
Map<K,V> tasks
List<E> verticesInCreationOrder
long[] stateTimestamps
System.currentTimeMillis()
when
the execution graph transitioned into a certain state. The index into this array is the
ordinal of the enum value, i.e. the timestamp when the graph went into state "RUNNING" is
at stateTimestamps[RUNNING.ordinal()]
.org.apache.flink.api.common.JobStatus state
ErrorInfo failureCause
String jsonPlan
StringifiedAccumulatorResult[] archivedUserAccumulators
org.apache.flink.api.common.ArchivedExecutionConfig archivedExecutionConfig
boolean isStoppable
Map<K,V> serializedUserAccumulators
CheckpointCoordinatorConfiguration jobCheckpointingConfiguration
CheckpointStatsSnapshot checkpointStatsSnapshot
String stateBackendName
ArchivedExecutionVertex[] taskVertices
JobVertexID id
String name
int parallelism
int maxParallelism
ResourceProfile resourceProfile
StringifiedAccumulatorResult[] archivedUserAccumulators
int subTaskIndex
EvictingBoundedList<T> priorExecutions
String taskNameWithSubtask
ArchivedExecution currentExecution
org.apache.flink.util.SerializedThrowable exception
long timestamp
long expectedModVersion
long actualModVersion
long numRecordsIn
long numRecordsOut
long numBytesIn
long numBytesOut
org.apache.flink.api.common.JobID jobId
String jobName
org.apache.flink.util.SerializedValue<T> serializedExecutionConfig
org.apache.flink.configuration.Configuration jobConfiguration
Collection<E> requiredJarFileBlobKeys
Collection<E> requiredClasspathURLs
IntermediateDataSetID intermediateDataSetID
ShuffleDescriptor shuffleDescriptor
JobVertexID jobVertexId
String taskName
int numberOfSubtasks
int maxNumberOfSubtaks
String invokableClassName
org.apache.flink.configuration.Configuration taskConfiguration
int maxFailuresPerInterval
org.apache.flink.api.common.time.Time failuresInterval
org.apache.flink.api.common.time.Time delayInterval
int maxNumberRestartAttempts
long delayBetweenRestartAttempts
int numberOfCPUCores
long sizeOfPhysicalMemory
long sizeOfJvmHeap
long sizeOfManagedMemory
boolean closed
InetSocketAddress address
int connectionIndex
SocketAddress address
ResultPartitionID partitionId
IntermediateResultPartitionID partitionId
ExecutionAttemptID producerId
IntermediateDataSetID consumedResultID
ExecutionAttemptID consumerID
IntermediateDataSetID id
JobVertex producer
List<E> consumers
ResultPartitionType resultType
JobVertex target
DistributionPattern distributionPattern
IntermediateDataSet source
IntermediateDataSetID sourceId
String shipStrategyName
String preProcessingOperationName
String operatorLevelCachingDescription
Map<K,V> taskVertices
org.apache.flink.configuration.Configuration jobConfiguration
org.apache.flink.api.common.JobID jobID
String jobName
ScheduleMode scheduleMode
org.apache.flink.util.SerializedValue<T> serializedExecutionConfig
JobCheckpointingSettings snapshotSettings
SavepointRestoreSettings savepointRestoreSettings
List<E> userJars
Map<K,V> userArtifacts
List<E> userJarBlobKeys
List<E> classpaths
JobVertexID id
ArrayList<E> idAlternatives
ArrayList<E> operatorIDs
ArrayList<E> operatorIdsAlternatives
ArrayList<E> results
ArrayList<E> inputs
int parallelism
int maxParallelism
org.apache.flink.api.common.operators.ResourceSpec minResources
org.apache.flink.api.common.operators.ResourceSpec preferredResources
org.apache.flink.configuration.Configuration configuration
String invokableClassName
boolean isStoppable
org.apache.flink.core.io.InputSplitSource<T extends org.apache.flink.core.io.InputSplit> inputSplitSource
String name
SlotSharingGroup slotSharingGroup
CoLocationGroup coLocationGroup
String operatorName
String operatorDescription
String operatorPrettyName
String resultOptimizerProperties
org.apache.flink.api.common.InputDependencyConstraint inputDependencyConstraint
String restorePath
boolean allowNonRestoredState
long checkpointInterval
long checkpointTimeout
long minPauseBetweenCheckpoints
int maxConcurrentCheckpoints
int tolerableCheckpointFailureNumber
CheckpointRetentionPolicy checkpointRetentionPolicy
boolean isExactlyOnce
false
, at least once mode has been configured. This is
not a necessary attribute, because the checkpointing mode is only relevant
for the stream tasks, but we expose it here to forward it to the web runtime
UI.boolean isPreferCheckpointForRecovery
List<E> verticesToTrigger
List<E> verticesToAcknowledge
List<E> verticesToConfirm
CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration
org.apache.flink.util.SerializedValue<T> defaultStateBackend
org.apache.flink.util.SerializedValue<T> masterHooks
Set<E> ids
SlotSharingGroupId slotSharingGroupId
org.apache.flink.api.common.operators.ResourceSpec resourceSpec
int slotIndex
AllocationID allocationId
org.apache.flink.api.common.JobID jobId
Collection<E> allocatedSlotInfos
ResourceID resourceID
ResourceManagerId resourceManagerId
ResourceID resourceManagerResourceId
org.apache.flink.api.common.JobID jobId
ApplicationStatus applicationStatus
Map<K,V> accumulatorResults
long netRuntime
org.apache.flink.util.SerializedThrowable serializedThrowable
null
if the job finished successfully.byte[] inputSplitData
protected Object readResolve() throws ObjectStreamException
int requestId
ExecutionAttemptID executionAttemptID
double backPressureRatio
org.apache.flink.api.common.JobID job
ExecutionAttemptID taskExecutionId
long checkpointId
TaskStateSnapshot subtaskState
CheckpointMetrics checkpointMetrics
Throwable reason
int numTaskManagersConnected
int numSlotsTotal
int numSlotsAvailable
org.apache.flink.api.common.JobID jobId
String jobName
long startTime
long endTime
long duration
org.apache.flink.api.common.JobStatus status
long lastUpdateTime
int[] tasksPerState
int numTasks
Collection<E> jobsWithStatus
org.apache.flink.api.common.JobID jobId
org.apache.flink.api.common.JobStatus jobStatus
int numJobsRunningOrPending
int numJobsFinished
int numJobsCancelled
int numJobsFailed
Collection<E> jobs
boolean includeRunning
boolean includeFinished
private Object readResolve()
private Object readResolve()
private Object readResolve()
byte[] serializedCounters
byte[] serializedGauges
byte[] serializedMeters
byte[] serializedHistograms
int numCounters
int numGauges
int numMeters
int numHistograms
org.apache.flink.api.common.typeutils.TypeComparatorFactory<T> typeComparator
int parallelism
org.apache.flink.api.common.typeutils.TypeComparatorFactory<T> comparatorFactory
org.apache.flink.configuration.Configuration config
org.apache.flink.api.common.JobID jobId
JobVertexID jobVertexId
int numKeyGroups
String registrationName
org.apache.flink.queryablestate.KvStateID[] kvStateIds
InetSocketAddress[] kvStateAddresses
int numRegisteredKeyGroups
String reason
int numberTaskManagers
int numberRegisteredSlots
int numberFreeSlots
org.apache.flink.api.common.JobID jobId
AllocationID allocationId
ResourceProfile resourceProfile
String targetAddress
String taskExecutorAddress
ResourceID resourceId
int dataPort
HardwareDescription hardwareDescription
ResourceProfile defaultSlotResourceProfile
ResourceProfile totalResourceProfile
int responseCode
int requestId
long endTimestamp
double[] subTaskBackPressureRatios
double maxSubTaskBackPressureRatio
OperatorBackPressureStats operatorBackPressureStats
boolean numBytesInComplete
boolean numBytesOutComplete
boolean numRecordsInComplete
boolean numRecordsOutComplete
JobIDDeserializer jobIdDeserializer
SerializedThrowableDeserializer serializedThrowableDeserializer
SerializedValueDeserializer serializedValueDeserializer
JobIDSerializer jobIdSerializer
SerializedValueSerializer serializedValueSerializer
SerializedThrowableSerializer serializedThrowableSerializer
TaskManagerMetricsInfo taskManagerMetrics
ResourceID resourceId
String address
int dataPort
long lastHeartbeat
int numberSlots
int numberAvailableSlots
HardwareDescription hardwareDescription
int responseCode
Serializable fencingToken
Serializable payload
private void readObject(ObjectInputStream ois) throws IOException, ClassNotFoundException
private void writeObject(ObjectOutputStream oos) throws IOException
IOException
org.apache.flink.util.SerializedValue<T> serializedMethodInvocation
ResourceID producerLocation
NettyShuffleDescriptor.PartitionConnectionInfo partitionConnectionInfo
ResultPartitionID resultPartitionID
ConnectionID connectionID
IntermediateDataSetID resultId
int totalNumberOfPartitions
IntermediateResultPartitionID partitionId
ResultPartitionType partitionType
int numberOfSubpartitions
int connectionIndex
ResultPartitionID resultPartitionID
org.apache.flink.api.common.typeutils.TypeSerializer<T> elementSerializer
protected final Object readResolve() throws ObjectStreamException
byte[] encodedReference
DirectoryStateHandle directoryStateHandle
KeyGroupRange keyGroupRange
String directoryString
long checkpointId
UUID backendIdentifier
StreamStateHandle metaDataState
Set<E> sharedStateHandleIDs
UUID backendIdentifier
SharedStateRegistry
.KeyGroupRange keyGroupRange
long checkpointId
Map<K,V> sharedState
Map<K,V> privateState
StreamStateHandle metaStateHandle
int startKeyGroup
int endKeyGroup
KeyGroupRange keyGroupRange
long[] offsets
KeyGroupRangeOffsets groupRangeOffsets
StreamStateHandle stateHandle
File[] allocationBaseDirs
org.apache.flink.api.common.JobID jobID
JobVertexID jobVertexID
int subtaskIndex
long[] offsets
OperatorStateHandle.Mode distributionMode
Map<K,V> stateNameToPartitionOffsets
StreamStateHandle delegateStateHandle
StreamStateHandle wrappedStreamStateHandle
StateObject jobManagerOwnedSnapshot
StateObject taskLocalSnapshot
org.apache.flink.core.fs.Path baseCheckpointPath
org.apache.flink.core.fs.Path baseSavepointPath
org.apache.flink.core.fs.Path filePath
long stateSize
org.apache.flink.core.fs.Path exclusiveCheckpointDir
FileStateHandle metadataFileHandle
String externalPointer
int fileStateThreshold
org.apache.flink.util.TernaryBoolean asynchronousSnapshots
int writeBufferSize
byte[] data
String handleName
ByteStreamStateHandle
with the exact same name must also have the exact same content in data.int maxStateSize
org.apache.flink.util.TernaryBoolean asynchronousSnapshots
Object userValue
long lastAccessTimestamp
Collection<E> accumulatorSnapshots
Collection<E> slotsStatus
SlotID slotID
ResourceProfile resourceProfile
AllocationID allocationID
org.apache.flink.api.common.JobID jobID
SlotReport slotReport
ClusterPartitionReport clusterPartitionReport
InstanceID registrationId
ResourceID resourceManagerResourceId
ClusterInformation clusterInformation
AllocationID allocationId
org.apache.flink.api.common.JobID jobId
Collection<E> entries
IntermediateDataSetID dataSetId
Set<E> hostedPartitions
int numTotalPartitions
AllocationID allocationId
int slotIndex
ResourceProfile resourceProfile
org.apache.flink.api.common.JobID jobID
ExecutionAttemptID executionId
ExecutionState executionState
org.apache.flink.util.SerializedThrowable throwable
AccumulatorSnapshot accumulators
IOMetrics ioMetrics
ResourceID resourceID
InetAddress inetAddress
String fqdnHostName
String hostName
int dataPort
String stringRepresentation
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.