Serialized Form
-
Package org.apache.flink.runtime
-
Class org.apache.flink.runtime.JobException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 1275864691743020176L
-
Class org.apache.flink.runtime.OperatorIDPair extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
generatedOperatorID
OperatorID generatedOperatorID
-
userDefinedOperatorID
OperatorID userDefinedOperatorID
-
userDefinedOperatorName
String userDefinedOperatorName
-
userDefinedOperatorUid
String userDefinedOperatorUid
-
-
-
Package org.apache.flink.runtime.accumulators
-
Class org.apache.flink.runtime.accumulators.AccumulatorSnapshot extends Object implements Serializable
- serialVersionUID:
- 42L
-
Serialized Fields
-
executionAttemptID
ExecutionAttemptID executionAttemptID
-
jobID
org.apache.flink.api.common.JobID jobID
-
userAccumulators
org.apache.flink.util.SerializedValue<Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>>> userAccumulators
Serialized user accumulators which may require the custom user class loader.
-
-
Class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult extends Object implements Serializable
- serialVersionUID:
- -4642311296836822611L
-
-
Package org.apache.flink.runtime.asyncprocessing
-
Class org.apache.flink.runtime.asyncprocessing.AsyncStateException extends RuntimeException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.StateRequest extends Object implements Serializable
-
Serialized Fields
-
context
RecordContext<K> context
The record context of this request. -
namespace
N namespace
-
payload
IN payload
The payload(input) of this request. -
state
org.apache.flink.api.common.state.v2.State state
The underlying state to be accessed, can be empty forStateRequestType.SYNC_POINT
. -
stateFuture
org.apache.flink.core.state.InternalStateFuture<OUT> stateFuture
The future to collect the result of the request. -
sync
boolean sync
-
type
StateRequestType type
The type of this request.
-
-
-
-
Package org.apache.flink.runtime.asyncprocessing.declare
-
Class org.apache.flink.runtime.asyncprocessing.declare.DeclarationException extends RuntimeException implements Serializable
-
-
Package org.apache.flink.runtime.asyncprocessing.functions
-
Class org.apache.flink.runtime.asyncprocessing.functions.DeclaringAsyncKeyedProcessFunction extends KeyedProcessFunction<K,I,O> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.asyncprocessing.operators
-
Class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator extends AbstractStreamOperator<OUT> implements Serializable
-
Serialized Fields
-
asyncExecutionController
AsyncExecutionController asyncExecutionController
-
currentProcessingContext
RecordContext currentProcessingContext
-
declarationManager
DeclarationManager declarationManager
-
environment
Environment environment
-
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2 extends AbstractStreamOperatorV2<OUT> implements Serializable
-
Serialized Fields
-
asyncExecutionController
AsyncExecutionController asyncExecutionController
-
currentProcessingContext
RecordContext currentProcessingContext
-
declarationManager
DeclarationManager declarationManager
-
environment
Environment environment
-
streamTask
StreamTask<?,?> streamTask
-
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator extends AbstractAsyncStateStreamOperator<OUT> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
userFunction
F extends org.apache.flink.api.common.functions.Function userFunction
The user function.
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.AsyncIntervalJoinOperator extends AbstractAsyncStateUdfStreamOperator<OUT,ProcessJoinFunction<T1,T2,OUT>> implements Serializable
- serialVersionUID:
- -5380774605111543477L
-
Serialized Fields
-
leftLateDataOutputTag
org.apache.flink.util.OutputTag<T1> leftLateDataOutputTag
-
leftTypeSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<T1> leftTypeSerializer
-
lowerBound
long lowerBound
-
rightLateDataOutputTag
org.apache.flink.util.OutputTag<T2> rightLateDataOutputTag
-
rightTypeSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<T2> rightTypeSerializer
-
upperBound
long upperBound
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.AsyncKeyedProcessOperator extends AbstractAsyncStateUdfStreamOperator<OUT,KeyedProcessFunction<K,IN,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.operators.AsyncStreamFlatMap extends AbstractAsyncStateUdfStreamOperator<OUT,org.apache.flink.api.common.functions.FlatMapFunction<IN,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.asyncprocessing.operators.windowing
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.AsyncEvictingWindowOperator extends AsyncWindowOperator<K,IN,org.apache.flink.api.common.state.v2.StateIterator<IN>,OUT,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.AsyncWindowOperator extends AbstractAsyncStateUdfStreamOperator<OUT,InternalAsyncWindowFunction<ACC,OUT,K,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allowedLateness
long allowedLateness
The allowed lateness for elements. This is used for:- Deciding if an element should be dropped from a window due to lateness.
- Clearing the state of a window if the system time passes the
window.maxTimestamp + allowedLateness
landmark.
-
keySelector
org.apache.flink.api.java.functions.KeySelector<IN,K> keySelector
-
keySerializer
org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer
For serializing the key in checkpoints. -
lateDataOutputTag
org.apache.flink.util.OutputTag<IN> lateDataOutputTag
OutputTag
to use for late arriving events. Elements for whichwindow.maxTimestamp + allowedLateness
is smaller than the current watermark will be emitted to this. -
trigger
AsyncTrigger<? super IN,? super W extends Window> trigger
-
windowAssigner
WindowAssigner<? super IN,W extends Window> windowAssigner
-
windowSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<W extends Window> windowSerializer
For serializing the window in checkpoints. -
windowStateDescriptor
org.apache.flink.api.common.state.v2.StateDescriptor<?> windowStateDescriptor
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.AsyncWindowOperator.WindowContext extends Object implements Serializable
-
Serialized Fields
-
window
DeclaredVariable<W extends Window> window
-
windowState
AsyncWindowOperator.AbstractPerWindowStateStore windowState
-
-
-
-
Package org.apache.flink.runtime.asyncprocessing.operators.windowing.functions
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.functions.InternalAggregateProcessAsyncWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessWindowFunction<V,R,K,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.functions.InternalIterableAsyncWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<WindowFunction<IN,OUT,KEY,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.functions.InternalIterableProcessAsyncWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessWindowFunction<IN,OUT,KEY,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.functions.InternalProcessWindowContext extends ProcessWindowFunction.Context implements Serializable
-
Serialized Fields
-
internalContext
InternalAsyncWindowFunction.InternalWindowContext internalContext
-
window
W extends Window window
-
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.functions.InternalSingleValueAsyncWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<WindowFunction<IN,OUT,KEY,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.functions.InternalSingleValueProcessAsyncWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessWindowFunction<IN,OUT,KEY,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.asyncprocessing.operators.windowing.triggers
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.triggers.AsyncContinuousEventTimeTrigger extends AsyncTrigger<Object,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
interval
long interval
-
stateDesc
org.apache.flink.api.common.state.v2.ReducingStateDescriptor<Long> stateDesc
When merging we take the lowest of all fire timestamps as the new fire timestamp.
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.triggers.AsyncCountTrigger extends AsyncTrigger<Object,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
maxCount
long maxCount
-
stateDesc
org.apache.flink.api.common.state.v2.ReducingStateDescriptor<Long> stateDesc
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.triggers.AsyncEventTimeTrigger extends AsyncTrigger<Object,TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.triggers.AsyncProcessingTimeTrigger extends AsyncTrigger<Object,TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.triggers.AsyncPurgingTrigger extends AsyncTrigger<T,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
nestedTrigger
AsyncTrigger<T,W extends Window> nestedTrigger
-
-
Class org.apache.flink.runtime.asyncprocessing.operators.windowing.triggers.AsyncTrigger extends Object implements Serializable
- serialVersionUID:
- -4104633972991191369L
-
-
Package org.apache.flink.runtime.blob
-
Class org.apache.flink.runtime.blob.BlobKey extends Object implements Serializable
- serialVersionUID:
- 3847117712521785209L
-
Serialized Fields
-
key
byte[] key
The byte buffer storing the actual key data. -
random
org.apache.flink.util.AbstractID random
Random component of the key. -
type
org.apache.flink.runtime.blob.BlobKey.BlobType type
(Internal) BLOB type - to be reflected by the inheriting sub-class.
-
-
Class org.apache.flink.runtime.blob.PermanentBlobKey extends BlobKey implements Serializable
-
Class org.apache.flink.runtime.blob.TransientBlobKey extends BlobKey implements Serializable
-
-
Package org.apache.flink.runtime.blocklist
-
Class org.apache.flink.runtime.blocklist.BlockedNode extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.broadcast
-
Class org.apache.flink.runtime.broadcast.InitializationTypeConflictException extends Exception implements Serializable
- serialVersionUID:
- -3930913982433642882L
-
Serialized Fields
-
type
Class<?> type
-
-
Class org.apache.flink.runtime.broadcast.MaterializationExpiredException extends Exception implements Serializable
- serialVersionUID:
- 7476456353634121934L
-
-
Package org.apache.flink.runtime.checkpoint
-
Class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats extends Object implements Serializable
- serialVersionUID:
- 1041218202028265151L
-
Serialized Fields
-
checkpointId
long checkpointId
ID of this checkpoint. -
numberOfSubtasks
int numberOfSubtasks
Total number of subtasks over all tasks. -
props
CheckpointProperties props
Properties of the checkpoint. -
taskStats
Map<JobVertexID,TaskStateStats> taskStats
TaskStateStats
accessible by their ID. -
triggerTimestamp
long triggerTimestamp
Timestamp when the checkpoint was triggered at the coordinator.
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointException extends Exception implements Serializable
- serialVersionUID:
- 3257526119022486948L
-
Serialized Fields
-
checkpointFailureReason
CheckpointFailureReason checkpointFailureReason
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointMetaData extends Object implements Serializable
- serialVersionUID:
- -2387652345781312442L
-
Serialized Fields
-
checkpointId
long checkpointId
The ID of the checkpoint. -
receiveTimestamp
long receiveTimestamp
The timestamp of the checkpoint receiving by this subtask. -
timestamp
long timestamp
The timestamp of the checkpoint triggering.
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointMetrics extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
alignmentDurationNanos
long alignmentDurationNanos
The duration (in nanoseconds) that the stream alignment for the checkpoint took. -
asyncDurationMillis
long asyncDurationMillis
The duration (in milliseconds) of the asynchronous part of the operator checkpoint. -
bytesPersistedDuringAlignment
long bytesPersistedDuringAlignment
-
bytesPersistedOfThisCheckpoint
long bytesPersistedOfThisCheckpoint
-
bytesProcessedDuringAlignment
long bytesProcessedDuringAlignment
-
checkpointStartDelayNanos
long checkpointStartDelayNanos
-
syncDurationMillis
long syncDurationMillis
The duration (in milliseconds) of the synchronous part of the operator checkpoint. -
totalBytesPersisted
long totalBytesPersisted
-
unalignedCheckpoint
boolean unalignedCheckpoint
Is the checkpoint completed as an unaligned checkpoint.
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointOptions extends Object implements Serializable
- serialVersionUID:
- 5010126558083292915L
-
Serialized Fields
-
alignedCheckpointTimeout
long alignedCheckpointTimeout
-
alignmentType
CheckpointOptions.AlignmentType alignmentType
-
checkpointType
SnapshotType checkpointType
Type of the checkpoint. -
targetLocation
CheckpointStorageLocationReference targetLocation
Target location for the checkpoint.
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointProperties extends Object implements Serializable
- serialVersionUID:
- 2L
-
Serialized Fields
-
checkpointType
SnapshotType checkpointType
Type - checkpoint / savepoint. -
discardCancelled
boolean discardCancelled
-
discardFailed
boolean discardFailed
-
discardFinished
boolean discardFinished
-
discardSubsumed
boolean discardSubsumed
-
discardSuspended
boolean discardSuspended
-
forced
boolean forced
This has a misleading name and actually means whether the snapshot must be triggered, or whether it may be rejected by the checkpoint coordinator if too many checkpoints are currently in progress. -
unclaimed
boolean unclaimed
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointsCleaner extends Object implements Serializable
- serialVersionUID:
- 2545865801947537790L
-
Serialized Fields
-
cleanUpFuture
CompletableFuture<Void> cleanUpFuture
-
lock
Object lock
-
numberOfCheckpointsToClean
int numberOfCheckpointsToClean
-
parallelMode
boolean parallelMode
-
subsumedCheckpoints
List<CompletedCheckpoint> subsumedCheckpoints
All subsumed checkpoints.
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts extends Object implements Serializable
- serialVersionUID:
- -5229425063269482528L
-
Serialized Fields
-
numCompletedCheckpoints
long numCompletedCheckpoints
Number of successfully completed checkpoints. -
numFailedCheckpoints
long numFailedCheckpoints
Number of failed checkpoints. -
numInProgressCheckpoints
int numInProgressCheckpoints
Number of in progress checkpoints. -
numRestoredCheckpoints
long numRestoredCheckpoints
Number of restored checkpoints. -
numTotalCheckpoints
long numTotalCheckpoints
Number of total checkpoints (in progress, completed, failed).
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory extends Object implements Serializable
- serialVersionUID:
- 7090320677606528415L
-
Serialized Fields
-
checkpointsHistory
List<AbstractCheckpointStats> checkpointsHistory
List over all available stats. Only updated onCheckpointStatsHistory.createSnapshot()
. -
latestCompletedCheckpoint
CompletedCheckpointStats latestCompletedCheckpoint
The latest successfully completed checkpoint. -
latestFailedCheckpoint
FailedCheckpointStats latestFailedCheckpoint
The latest failed checkpoint. -
latestSavepoint
CompletedCheckpointStats latestSavepoint
The latest successfully completed savepoint. -
maxSize
int maxSize
Maximum array size. -
readOnly
boolean readOnly
Flag indicating whether this the history is read-only. -
recentCheckpoints
LinkedHashMap<Long,AbstractCheckpointStats> recentCheckpoints
Map of all available stats keyed by their ID.
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot extends Object implements Serializable
- serialVersionUID:
- 8914278419087217964L
-
Serialized Fields
-
counts
CheckpointStatsCounts counts
Snapshot of the checkpoint counts. -
history
CheckpointStatsHistory history
Snapshot of the checkpoint history. -
latestRestoredCheckpoint
RestoredCheckpointStats latestRestoredCheckpoint
The latest restored checkpoint operation. -
summary
CompletedCheckpointStatsSummarySnapshot summary
Snapshot of the completed checkpoints summary stats.
-
-
Class org.apache.flink.runtime.checkpoint.CheckpointType extends Object implements Serializable
-
Serialized Fields
-
name
String name
-
sharingFilesStrategy
SnapshotType.SharingFilesStrategy sharingFilesStrategy
-
-
-
Class org.apache.flink.runtime.checkpoint.CompletedCheckpoint extends Object implements Serializable
- serialVersionUID:
- -8360248179615702014L
-
Serialized Fields
-
checkpointID
long checkpointID
The ID (logical timestamp) of the checkpoint. -
completionTimestamp
long completionTimestamp
The timestamp when the checkpoint was completed. -
externalPointer
String externalPointer
External pointer to the completed checkpoint (for example file path). -
job
org.apache.flink.api.common.JobID job
The ID of the job that the checkpoint belongs to. -
masterHookStates
Collection<MasterState> masterHookStates
States that were created by a hook on the master (in the checkpoint coordinator). -
metadataHandle
StreamStateHandle metadataHandle
The state handle to the externalized meta data. -
operatorStates
Map<OperatorID,OperatorState> operatorStates
States of the different operator groups belonging to this checkpoint. -
props
CheckpointProperties props
Properties of this checkpoint. Might change during recovery. -
restoredProps
CheckpointProperties restoredProps
Properties of this checkpoint as they were during checkpoint creation. Might be null for older versions. -
storageLocation
CompletedCheckpointStorageLocation storageLocation
The location where the checkpoint is stored. -
timestamp
long timestamp
The timestamp when the checkpoint was triggered.
-
-
Class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats extends AbstractCheckpointStats implements Serializable
- serialVersionUID:
- 138833868551861344L
-
Serialized Fields
-
checkpointedSize
long checkpointedSize
Total persisted data size over all subtasks of this checkpoint. -
discarded
boolean discarded
Flag indicating whether the checkpoint was discarded. -
externalPointer
String externalPointer
The external pointer of the checkpoint. -
latestAcknowledgedSubtask
SubtaskStateStats latestAcknowledgedSubtask
The latest acknowledged subtask stats. -
persistedData
long persistedData
-
processedData
long processedData
-
stateSize
long stateSize
Total checkpoint state size over all subtasks. -
unalignedCheckpoint
boolean unalignedCheckpoint
-
-
Class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary extends Object implements Serializable
- serialVersionUID:
- 5784360461635814038L
-
Serialized Fields
-
checkpointedSize
StatsSummary checkpointedSize
-
duration
StatsSummary duration
Duration statistics for all completed checkpoints. -
persistedData
StatsSummary persistedData
-
processedData
StatsSummary processedData
-
stateSize
StatsSummary stateSize
State size statistics for all completed checkpoints.
-
-
Class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummarySnapshot extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
checkpointedSize
StatsSummarySnapshot checkpointedSize
-
duration
StatsSummarySnapshot duration
-
persistedData
StatsSummarySnapshot persistedData
-
processedData
StatsSummarySnapshot processedData
-
stateSize
StatsSummarySnapshot stateSize
-
-
Class org.apache.flink.runtime.checkpoint.FailedCheckpointStats extends PendingCheckpointStats implements Serializable
- serialVersionUID:
- 8000748529515900106L
-
Serialized Fields
-
failureMsg
String failureMsg
Optional failure message. -
failureTimestamp
long failureTimestamp
Timestamp when the checkpoint was failed at the coordinator.
-
-
Class org.apache.flink.runtime.checkpoint.FinishedOperatorSubtaskState extends OperatorSubtaskState implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.checkpoint.FinishedTaskStateProvider.PartialFinishingNotSupportedByStateException extends org.apache.flink.util.FlinkRuntimeException implements Serializable
-
Class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState extends OperatorState implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor extends Object implements Serializable
- serialVersionUID:
- -3396674344669796295L
-
Serialized Fields
-
gateOrPartitionDescriptors
InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor[] gateOrPartitionDescriptors
Set when several operator instances are merged into one.
-
-
Class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
ambiguousSubtaskIndexes
Set<Integer> ambiguousSubtaskIndexes
All channels where upstream duplicates data (only valid for downstream mappings). -
mappingType
InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType mappingType
-
oldSubtaskIndexes
int[] oldSubtaskIndexes
Set when several operator instances are merged into one. -
rescaledChannelsMappings
RescaleMappings rescaledChannelsMappings
Set when channels are merged because the connected operator has been rescaled for each gate/partition.
-
-
Class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
restoreCheckpointId
long restoreCheckpointId
The id of the checkpoint from which we restore. -
taskStateSnapshot
TaskStateSnapshot taskStateSnapshot
The state for this task to restore.
-
-
Class org.apache.flink.runtime.checkpoint.MasterState extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
bytes
byte[] bytes
-
name
String name
-
version
int version
-
-
Class org.apache.flink.runtime.checkpoint.OperatorState extends Object implements Serializable
- serialVersionUID:
- -4845578005863201810L
-
Serialized Fields
-
coordinatorState
ByteStreamStateHandle coordinatorState
The state of the operator coordinator. Null, if no such state exists. -
maxParallelism
int maxParallelism
The maximum parallelism (for number of KeyGroups) of the operator when the job was first created. -
operatorID
OperatorID operatorID
The id of the operator. -
operatorName
String operatorName
The name of the operator. -
operatorSubtaskStates
Map<Integer,OperatorSubtaskState> operatorSubtaskStates
The handles to states created by the parallel tasks: subtaskIndex -> subtaskstate. -
operatorUid
String operatorUid
The Uid of the operator. -
parallelism
int parallelism
The parallelism of the operator when it was checkpointed.
-
-
Class org.apache.flink.runtime.checkpoint.OperatorSubtaskState extends Object implements Serializable
- serialVersionUID:
- -2394696997971923995L
-
Serialized Fields
-
checkpointedSize
long checkpointedSize
-
inputChannelState
StateObjectCollection<InputChannelStateHandle> inputChannelState
-
inputRescalingDescriptor
InflightDataRescalingDescriptor inputRescalingDescriptor
The subpartitions mappings per partition set when the output operator for a partition was rescaled. The key is the partition id and the value contains all subtask indexes of the output operator before rescaling. Note that this field is only set byStateAssignmentOperation
and will not be persisted in the checkpoint itself as it can only be calculated if the post-recovery scale factor is known. -
managedKeyedState
StateObjectCollection<KeyedStateHandle> managedKeyedState
Snapshot fromKeyedStateBackend
. -
managedOperatorState
StateObjectCollection<OperatorStateHandle> managedOperatorState
Snapshot from theOperatorStateBackend
. -
outputRescalingDescriptor
InflightDataRescalingDescriptor outputRescalingDescriptor
The input channel mappings per input set when the input operator for a gate was rescaled. The key is the gate index and the value contains all subtask indexes of the input operator before rescaling. Note that this field is only set byStateAssignmentOperation
and will not be persisted in the checkpoint itself as it can only be calculated if the post-recovery scale factor is known. -
rawKeyedState
StateObjectCollection<KeyedStateHandle> rawKeyedState
Snapshot written usingKeyedStateCheckpointOutputStream
. -
rawOperatorState
StateObjectCollection<OperatorStateHandle> rawOperatorState
Snapshot written usingOperatorStateCheckpointOutputStream
. -
resultSubpartitionState
StateObjectCollection<ResultSubpartitionStateHandle> resultSubpartitionState
-
stateSize
long stateSize
The state size. This is also part of the deserialized state handle. We store it here in order to not deserialize the state handle when gathering stats.
-
-
Class org.apache.flink.runtime.checkpoint.PendingCheckpointStats extends AbstractCheckpointStats implements Serializable
- serialVersionUID:
- -973959257699390327L
-
Serialized Fields
-
currentCheckpointedSize
long currentCheckpointedSize
-
currentNumAcknowledgedSubtasks
int currentNumAcknowledgedSubtasks
The current number of acknowledged subtasks. -
currentPersistedData
long currentPersistedData
-
currentProcessedData
long currentProcessedData
-
currentStateSize
long currentStateSize
Current checkpoint state size over all collected subtasks. -
latestAcknowledgedSubtask
SubtaskStateStats latestAcknowledgedSubtask
Stats of the latest acknowledged subtask. -
unalignedCheckpoint
boolean unalignedCheckpoint
-
-
Class org.apache.flink.runtime.checkpoint.RescaleMappings extends Object implements Serializable
- serialVersionUID:
- -8719670050630674631L
-
Serialized Fields
-
mappings
int[][] mappings
The mapping from source to multiple targets. In most cases, the targets arrays are of different sizes. -
numberOfSources
int numberOfSources
-
numberOfTargets
int numberOfTargets
-
-
Class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats extends Object implements Serializable
- serialVersionUID:
- 2305815319666360821L
-
Serialized Fields
-
checkpointId
long checkpointId
ID of the restored checkpoint. -
externalPath
String externalPath
Optional external path. -
props
CheckpointProperties props
Properties of the restored checkpoint. -
restoreTimestamp
long restoreTimestamp
Timestamp when the checkpoint was restored at the coordinator. -
stateSize
long stateSize
-
-
Class org.apache.flink.runtime.checkpoint.SavepointType extends Object implements Serializable
-
Serialized Fields
-
formatType
org.apache.flink.core.execution.SavepointFormatType formatType
-
name
String name
-
postCheckpointAction
SavepointType.PostCheckpointAction postCheckpointAction
-
-
-
Class org.apache.flink.runtime.checkpoint.StateObjectCollection extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
stateObjects
Collection<T extends StateObject> stateObjects
Wrapped collection that contains the state objects.
-
-
Class org.apache.flink.runtime.checkpoint.StatsSummary extends Object implements Serializable
- serialVersionUID:
- 1769601903483446707L
-
Serialized Fields
-
count
long count
Count of added values. -
histogram
org.apache.flink.metrics.Histogram histogram
Histogram for the values seen. Must be serializable so that history server can display it. Not used for min/max/sum because it is a sliding window histogram. -
max
long max
Current max value. -
min
long min
Current min value. -
sum
long sum
Sum of all added values.
-
-
Class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
count
long count
-
histogram
org.apache.flink.metrics.HistogramStatistics histogram
-
max
long max
-
min
long min
-
sum
long sum
-
-
Class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
durationMetrics
Map<String,Long> durationMetrics
-
endTs
long endTs
-
startTs
long startTs
WARNING! When adding new fields make sure that the math to calculate various durations in this class's getters is still correct. -
status
InitializationStatus status
-
-
Class org.apache.flink.runtime.checkpoint.SubtaskState extends Object implements Serializable
- serialVersionUID:
- -2394696997971923995L
-
Serialized Fields
-
managedKeyedState
KeyedStateHandle managedKeyedState
Deprecated.Snapshot fromKeyedStateBackend
. -
managedOperatorState
ChainedStateHandle<OperatorStateHandle> managedOperatorState
Deprecated.Snapshot from theOperatorStateBackend
. -
rawKeyedState
KeyedStateHandle rawKeyedState
Deprecated.Snapshot written usingKeyedStateCheckpointOutputStream
. -
rawOperatorState
ChainedStateHandle<OperatorStateHandle> rawOperatorState
Deprecated.Snapshot written usingOperatorStateCheckpointOutputStream
. -
stateSize
long stateSize
Deprecated.The state size. This is also part of the deserialized state handle. We store it here in order to not deserialize the state handle when gathering stats.
-
-
Class org.apache.flink.runtime.checkpoint.SubtaskStateStats extends Object implements Serializable
- serialVersionUID:
- 8928594531621862214L
-
Serialized Fields
-
ackTimestamp
long ackTimestamp
Timestamp when the ack from this sub task was received at the coordinator. -
alignmentDuration
long alignmentDuration
Alignment duration in milliseconds. -
asyncCheckpointDuration
long asyncCheckpointDuration
Checkpoint duration at the operator (async part) in milliseconds. -
checkpointedSize
long checkpointedSize
-
checkpointStartDelay
long checkpointStartDelay
Checkpoint start delay in milliseconds. -
completed
boolean completed
Is the checkpoint completed by this subtask. -
persistedData
long persistedData
-
processedData
long processedData
-
stateSize
long stateSize
Size of the checkpointed state at this subtask. -
subtaskIndex
int subtaskIndex
-
syncCheckpointDuration
long syncCheckpointDuration
Checkpoint duration at the operator (sync part) in milliseconds. -
unalignedCheckpoint
boolean unalignedCheckpoint
Is the checkpoint completed as an unaligned checkpoint.
-
-
Class org.apache.flink.runtime.checkpoint.TaskState extends Object implements Serializable
- serialVersionUID:
- -4845578005863201810L
-
Serialized Fields
-
chainLength
int chainLength
Deprecated.length of the operator chain. -
jobVertexID
JobVertexID jobVertexID
Deprecated. -
maxParallelism
int maxParallelism
Deprecated.maximum parallelism of the operator when the job was first created. -
parallelism
int parallelism
Deprecated.parallelism of the operator when it was checkpointed. -
subtaskStates
Map<Integer,SubtaskState> subtaskStates
Deprecated.handles to non-partitioned states, subtaskindex -> subtaskstate.
-
-
Class org.apache.flink.runtime.checkpoint.TaskStateSnapshot extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
isTaskDeployedAsFinished
boolean isTaskDeployedAsFinished
-
isTaskFinished
boolean isTaskFinished
-
subtaskStatesByOperatorID
Map<OperatorID,OperatorSubtaskState> subtaskStatesByOperatorID
Mapping from an operator id to the state of one subtask of this operator.
-
-
Class org.apache.flink.runtime.checkpoint.TaskStateStats extends Object implements Serializable
- serialVersionUID:
- 531803101206574444L
-
Serialized Fields
-
jobVertexId
JobVertexID jobVertexId
ID of the task the stats belong to. -
latestAckedSubtaskStats
SubtaskStateStats latestAckedSubtaskStats
-
numAcknowledgedSubtasks
int numAcknowledgedSubtasks
-
subtaskStats
SubtaskStateStats[] subtaskStats
-
summaryStats
TaskStateStats.TaskStateStatsSummary summaryStats
A summary of the subtask stats.
-
-
Class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary extends Object implements Serializable
- serialVersionUID:
- 1009476026522091909L
-
Serialized Fields
-
ackTimestamp
StatsSummary ackTimestamp
-
alignmentDuration
StatsSummary alignmentDuration
-
asyncCheckpointDuration
StatsSummary asyncCheckpointDuration
-
checkpointedSize
StatsSummary checkpointedSize
-
checkpointStartDelay
StatsSummary checkpointStartDelay
-
persistedData
StatsSummary persistedData
-
processedData
StatsSummary processedData
-
stateSize
StatsSummary stateSize
-
syncCheckpointDuration
StatsSummary syncCheckpointDuration
-
-
-
Package org.apache.flink.runtime.checkpoint.channel
-
Class org.apache.flink.runtime.checkpoint.channel.InputChannelInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
gateIdx
int gateIdx
-
inputChannelIdx
int inputChannelIdx
-
-
Class org.apache.flink.runtime.checkpoint.channel.ResultSubpartitionInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
partitionIdx
int partitionIdx
-
subPartitionIdx
int subPartitionIdx
-
-
-
Package org.apache.flink.runtime.checkpoint.filemerging
-
Class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile.LogicalFileId extends org.apache.flink.util.StringBasedID implements Serializable
-
-
Package org.apache.flink.runtime.client
-
Class org.apache.flink.runtime.client.DuplicateJobSubmissionException extends JobSubmissionException implements Serializable
- serialVersionUID:
- 2917336585664347210L
-
Serialized Fields
-
globallyTerminated
boolean globallyTerminated
-
-
Class org.apache.flink.runtime.client.JobCancellationException extends JobExecutionException implements Serializable
- serialVersionUID:
- 2818087325120827526L
-
Class org.apache.flink.runtime.client.JobExecutionException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 2818087325120827525L
-
Serialized Fields
-
jobID
org.apache.flink.api.common.JobID jobID
-
-
Class org.apache.flink.runtime.client.JobInitializationException extends JobExecutionException implements Serializable
- serialVersionUID:
- 2818087325120827526L
-
Class org.apache.flink.runtime.client.JobStatusMessage extends Object implements Serializable
-
Serialized Fields
-
jobId
org.apache.flink.api.common.JobID jobId
-
jobName
String jobName
-
jobState
org.apache.flink.api.common.JobStatus jobState
-
startTime
long startTime
-
-
-
Class org.apache.flink.runtime.client.JobSubmissionException extends JobExecutionException implements Serializable
- serialVersionUID:
- 2818087325120827526L
-
Class org.apache.flink.runtime.client.SerializedJobExecutionResult extends Object implements Serializable
- serialVersionUID:
- -6301865617099921789L
-
-
Package org.apache.flink.runtime.clusterframework
-
Class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters extends Object implements Serializable
- serialVersionUID:
- -3096987654278064670L
-
Serialized Fields
-
taskExecutorProcessSpec
TaskExecutorProcessSpec taskExecutorProcessSpec
-
taskManagerEnv
HashMap<String,String> taskManagerEnv
Environment variables to add to the Java process.
-
-
Class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec extends CommonProcessMemorySpec<TaskExecutorFlinkMemory> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.clusterframework.types
-
Class org.apache.flink.runtime.clusterframework.types.AllocationID extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.clusterframework.types.ResourceID extends Object implements Serializable
- serialVersionUID:
- 42L
-
Class org.apache.flink.runtime.clusterframework.types.ResourceProfile extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readResolve
private Object readResolve()
-
-
Serialized Fields
-
cpuCores
org.apache.flink.api.common.resources.CPUResource cpuCores
How many cpu cores are needed. Can be null only if it is unknown. -
extendedResources
Map<String,org.apache.flink.api.common.resources.ExternalResource> extendedResources
A extensible field for user specified resources fromResourceSpec
. -
managedMemory
org.apache.flink.configuration.MemorySize managedMemory
How much managed memory is needed. -
networkMemory
org.apache.flink.configuration.MemorySize networkMemory
How much network memory is needed. -
taskHeapMemory
org.apache.flink.configuration.MemorySize taskHeapMemory
How much task heap memory is needed. -
taskOffHeapMemory
org.apache.flink.configuration.MemorySize taskOffHeapMemory
How much task off-heap memory is needed.
-
-
Class org.apache.flink.runtime.clusterframework.types.SlotID extends Object implements Serializable
- serialVersionUID:
- -6399206032549807771L
-
Serialized Fields
-
resourceId
ResourceID resourceId
The resource id which this slot located -
slotNumber
int slotNumber
The numeric id for single slot
-
-
-
Package org.apache.flink.runtime.deployment
-
Class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor extends Object implements Serializable
- serialVersionUID:
- -7143441863165366704L
-
Serialized Fields
-
consumedPartitionType
ResultPartitionType consumedPartitionType
The type of the partition the input gate is going to consume. -
consumedResultId
IntermediateDataSetID consumedResultId
The ID of the consumed intermediate result. Each input gate consumes partitions of the intermediate result specified by this ID. This ID also identifies the input gate at the consuming task. -
consumedSubpartitionContext
org.apache.flink.runtime.deployment.ConsumedSubpartitionContext consumedSubpartitionContext
Provides information about the number of consumed shuffle descriptors and the mapping between consumed shuffle descriptor ranges and their corresponding subpartition ranges. -
numberOfInputChannels
int numberOfInputChannels
Number of input channels. -
serializedInputChannels
List<TaskDeploymentDescriptor.MaybeOffloaded<TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>> serializedInputChannels
Serialized value of shuffle descriptors.
-
-
Class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor extends Object implements Serializable
- serialVersionUID:
- 6343547936086963705L
-
Serialized Fields
-
maxParallelism
int maxParallelism
-
partitionDescriptor
PartitionDescriptor partitionDescriptor
-
shuffleDescriptor
ShuffleDescriptor shuffleDescriptor
-
-
Class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor extends Object implements Serializable
- serialVersionUID:
- -3233562176034358530L
-
Serialized Fields
-
allocationId
AllocationID allocationId
The allocation ID of the slot in which the task shall be run. -
executionId
ExecutionAttemptID executionId
The ID referencing the attempt to execute the task. -
inputGates
List<InputGateDeploymentDescriptor> inputGates
The list of consumed intermediate result partitions. -
jobId
org.apache.flink.api.common.JobID jobId
The ID referencing the job this task belongs to.NOTE: this is redundant to the information stored in
TaskDeploymentDescriptor.serializedJobInformation
but needed in order to restore offloaded data. -
producedPartitions
List<ResultPartitionDeploymentDescriptor> producedPartitions
The list of produced intermediate result partition deployment descriptors. -
serializedJobInformation
TaskDeploymentDescriptor.MaybeOffloaded<JobInformation> serializedJobInformation
Serialized job information if non-offloaded or PermanentBlobKey if offloaded. -
serializedTaskInformation
TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation> serializedTaskInformation
Serialized task information if non-offloaded or PermanentBlobKey if offloaded. -
taskRestore
JobManagerTaskRestore taskRestore
Information to restore the task. This can be null if there is no state to restore.
-
-
Class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.MaybeOffloaded extends Object implements Serializable
- serialVersionUID:
- 5977104446396536907L
-
Class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded extends TaskDeploymentDescriptor.MaybeOffloaded<T> implements Serializable
- serialVersionUID:
- 4246628617754862463L
-
Serialized Fields
-
serializedValue
org.apache.flink.util.SerializedValue<T> serializedValue
The serialized value.
-
-
Class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded extends TaskDeploymentDescriptor.MaybeOffloaded<T> implements Serializable
- serialVersionUID:
- 4544135485379071679L
-
Serialized Fields
-
serializedValueKey
PermanentBlobKey serializedValueKey
The key of the offloaded value BLOB.
-
-
Class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
index
int index
-
shuffleDescriptor
ShuffleDescriptor shuffleDescriptor
-
-
Class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
shuffleDescriptors
TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex[] shuffleDescriptors
-
-
-
Package org.apache.flink.runtime.dispatcher
-
Class org.apache.flink.runtime.dispatcher.DispatcherException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 3781733042984381286L
-
Class org.apache.flink.runtime.dispatcher.DispatcherId extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- -1654056277003743966L
-
Class org.apache.flink.runtime.dispatcher.JobCancellationFailedException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- -5351974867056033752L
-
Class org.apache.flink.runtime.dispatcher.OperationAlreadyFailedException extends DispatcherException implements Serializable
-
Class org.apache.flink.runtime.dispatcher.UnavailableDispatcherOperationException extends DispatcherException implements Serializable
- serialVersionUID:
- -45499335133622792L
-
Class org.apache.flink.runtime.dispatcher.UnknownOperationKeyException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.entrypoint
-
Class org.apache.flink.runtime.entrypoint.ClusterEntrypointException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- -3855286807063809945L
-
Class org.apache.flink.runtime.entrypoint.ClusterInformation extends Object implements Serializable
- serialVersionUID:
- 316958921518479205L
-
Serialized Fields
-
blobServerHostname
String blobServerHostname
-
blobServerPort
int blobServerPort
-
-
Class org.apache.flink.runtime.entrypoint.FlinkParseException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 5164983338744708430L
-
-
Package org.apache.flink.runtime.execution
-
Class org.apache.flink.runtime.execution.CancelTaskException extends RuntimeException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.execution.SuppressRestartsException extends RuntimeException implements Serializable
- serialVersionUID:
- 221873676920848349L
-
-
Package org.apache.flink.runtime.executiongraph
-
Class org.apache.flink.runtime.executiongraph.ArchivedExecution extends Object implements Serializable
- serialVersionUID:
- 4817108757483345173L
-
Serialized Fields
-
assignedAllocationID
AllocationID assignedAllocationID
-
assignedResourceLocation
TaskManagerLocation assignedResourceLocation
-
attemptId
ExecutionAttemptID attemptId
-
failureInfo
ErrorInfo failureInfo
-
ioMetrics
IOMetrics ioMetrics
-
state
ExecutionState state
-
stateEndTimestamps
long[] stateEndTimestamps
-
stateTimestamps
long[] stateTimestamps
-
userAccumulators
StringifiedAccumulatorResult[] userAccumulators
-
-
Class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph extends Object implements Serializable
- serialVersionUID:
- 7231383912742578428L
-
Serialized Fields
-
archivedExecutionConfig
org.apache.flink.api.common.ArchivedExecutionConfig archivedExecutionConfig
-
archivedUserAccumulators
StringifiedAccumulatorResult[] archivedUserAccumulators
-
changelogStorageName
String changelogStorageName
-
checkpointStatsSnapshot
CheckpointStatsSnapshot checkpointStatsSnapshot
-
checkpointStorageName
String checkpointStorageName
-
failureCause
ErrorInfo failureCause
The exception that caused the job to fail. This is set to the first root exception that was not recoverable and triggered job failure -
isStoppable
boolean isStoppable
-
jobCheckpointingConfiguration
CheckpointCoordinatorConfiguration jobCheckpointingConfiguration
-
jobID
org.apache.flink.api.common.JobID jobID
The ID of the job this graph has been built for. -
jobName
String jobName
The name of the original job graph. -
jobType
JobType jobType
The job type of the job execution. -
jsonPlan
String jsonPlan
-
pendingOperatorCount
int pendingOperatorCount
-
serializedUserAccumulators
Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> serializedUserAccumulators
-
state
org.apache.flink.api.common.JobStatus state
Current status of the job execution. -
stateBackendName
String stateBackendName
-
stateChangelogEnabled
org.apache.flink.util.TernaryBoolean stateChangelogEnabled
-
stateTimestamps
long[] stateTimestamps
Timestamps (in milliseconds as returned bySystem.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 atstateTimestamps[RUNNING.ordinal()]
. -
streamGraphJson
String streamGraphJson
-
tasks
Map<JobVertexID,ArchivedExecutionJobVertex> tasks
All job vertices that are part of this graph. -
verticesInCreationOrder
List<ArchivedExecutionJobVertex> verticesInCreationOrder
All vertices, in the order in which they were created. *
-
-
Class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex extends Object implements Serializable
- serialVersionUID:
- -5768187638639437957L
-
Serialized Fields
-
archivedUserAccumulators
StringifiedAccumulatorResult[] archivedUserAccumulators
-
id
JobVertexID id
-
maxParallelism
int maxParallelism
-
name
String name
-
parallelism
int parallelism
-
resourceProfile
ResourceProfile resourceProfile
-
slotSharingGroup
SlotSharingGroup slotSharingGroup
-
taskVertices
ArchivedExecutionVertex[] taskVertices
-
-
Class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex extends Object implements Serializable
- serialVersionUID:
- -6708241535015028576L
-
Serialized Fields
-
currentExecution
ArchivedExecution currentExecution
-
currentExecutions
Collection<AccessExecution> currentExecutions
-
executionHistory
ExecutionHistory executionHistory
-
subTaskIndex
int subTaskIndex
-
taskNameWithSubtask
String taskNameWithSubtask
The name in the format "myTask (2/7)", cached to avoid frequent string concatenations.
-
-
Class org.apache.flink.runtime.executiongraph.ErrorInfo extends Object implements Serializable
- serialVersionUID:
- -6138942031953594202L
-
Serialized Fields
-
exception
org.apache.flink.util.SerializedThrowable exception
The exception that we keep holding forever. Has no strong reference to any user-defined code. -
timestamp
long timestamp
-
-
Class org.apache.flink.runtime.executiongraph.ExecutionAttemptID extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attemptNumber
int attemptNumber
-
executionGraphId
ExecutionGraphID executionGraphId
-
executionVertexId
ExecutionVertexID executionVertexId
-
-
Class org.apache.flink.runtime.executiongraph.ExecutionGraphException extends Exception implements Serializable
- serialVersionUID:
- -8253451032797220657L
-
Class org.apache.flink.runtime.executiongraph.ExecutionGraphID extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.executiongraph.ExecutionHistory extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
historicalExecutions
org.apache.flink.runtime.executiongraph.ExecutionHistory.BoundedLinkedHashMap<Integer,ArchivedExecution> historicalExecutions
-
maxAttemptNumber
int maxAttemptNumber
-
-
Class org.apache.flink.runtime.executiongraph.ExecutionVertexInputInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
consumedSubpartitionGroups
Map<IndexRange,IndexRange> consumedSubpartitionGroups
-
subtaskIndex
int subtaskIndex
-
-
Class org.apache.flink.runtime.executiongraph.IllegalExecutionStateException extends IllegalStateException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.executiongraph.IndexRange extends Object implements Serializable
-
Serialized Fields
-
endIndex
int endIndex
-
startIndex
int startIndex
-
-
-
Class org.apache.flink.runtime.executiongraph.IOMetrics extends Object implements Serializable
- serialVersionUID:
- -7208093607556457183L
-
Serialized Fields
-
accumulateBackPressuredTime
long accumulateBackPressuredTime
-
accumulateBusyTime
double accumulateBusyTime
-
accumulateIdleTime
long accumulateIdleTime
-
numBytesIn
long numBytesIn
-
numBytesOut
long numBytesOut
-
numRecordsIn
long numRecordsIn
-
numRecordsOut
long numRecordsOut
-
resultPartitionBytes
Map<IntermediateResultPartitionID,ResultPartitionBytes> resultPartitionBytes
-
-
Class org.apache.flink.runtime.executiongraph.JobInformation extends Object implements Serializable
- serialVersionUID:
- 8367087049937822140L
-
Serialized Fields
-
jobConfiguration
org.apache.flink.configuration.UnmodifiableConfiguration jobConfiguration
Configuration of the job. -
jobId
org.apache.flink.api.common.JobID jobId
Id of the job. -
jobName
String jobName
Job name. -
jobType
JobType jobType
Type of the job. -
requiredClasspathURLs
org.apache.flink.shaded.guava32.com.google.common.collect.ImmutableCollection<URL> requiredClasspathURLs
URLs specifying the classpath to add to the class loader. -
requiredJarFileBlobKeys
org.apache.flink.shaded.guava32.com.google.common.collect.ImmutableCollection<PermanentBlobKey> requiredJarFileBlobKeys
Blob keys for the required jar files. -
serializedExecutionConfig
org.apache.flink.util.SerializedValue<org.apache.flink.api.common.ExecutionConfig> serializedExecutionConfig
Serialized execution config because it can contain user code classes.
-
-
Class org.apache.flink.runtime.executiongraph.JobVertexInputInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
executionVertexInputInfos
List<ExecutionVertexInputInfo> executionVertexInputInfos
-
-
Class org.apache.flink.runtime.executiongraph.PartitionInfo extends Object implements Serializable
- serialVersionUID:
- 1724490660830968430L
-
Serialized Fields
-
intermediateDataSetID
IntermediateDataSetID intermediateDataSetID
-
shuffleDescriptor
ShuffleDescriptor shuffleDescriptor
-
-
Class org.apache.flink.runtime.executiongraph.ResultPartitionBytes extends Object implements Serializable
-
Serialized Fields
-
subpartitionBytes
long[] subpartitionBytes
-
-
-
Class org.apache.flink.runtime.executiongraph.TaskInformation extends Object implements Serializable
- serialVersionUID:
- -9006218793155953789L
-
Serialized Fields
-
invokableClassName
String invokableClassName
Class name of the invokable to run. -
jobVertexId
JobVertexID jobVertexId
Job vertex id of the associated job vertex. -
maxNumberOfSubtasks
int maxNumberOfSubtasks
The maximum parallelism == number of key groups. -
numberOfSubtasks
int numberOfSubtasks
The number of subtasks for this operator. -
taskConfiguration
org.apache.flink.configuration.Configuration taskConfiguration
Configuration for the task. -
taskName
String taskName
Name of the task.
-
-
-
Package org.apache.flink.runtime.instance
-
Class org.apache.flink.runtime.instance.HardwareDescription extends Object implements Serializable
- serialVersionUID:
- 3380016608300325361L
-
Serialized Fields
-
numberOfCPUCores
int numberOfCPUCores
The number of CPU cores available to the JVM on the compute node. -
sizeOfJvmHeap
long sizeOfJvmHeap
The size of the JVM heap memory -
sizeOfManagedMemory
long sizeOfManagedMemory
The size of the memory managed by the system for caching, hashing, sorting, ... -
sizeOfPhysicalMemory
long sizeOfPhysicalMemory
The size of physical memory in bytes available on the compute node.
-
-
Class org.apache.flink.runtime.instance.InstanceID extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.instance.SlotSharingGroupId extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 8837647978345422042L
-
-
Package org.apache.flink.runtime.io.compression
-
Class org.apache.flink.runtime.io.compression.BufferCompressionException extends RuntimeException implements Serializable
-
Class org.apache.flink.runtime.io.compression.BufferDecompressionException extends RuntimeException implements Serializable
-
-
Package org.apache.flink.runtime.io.disk.iomanager
-
Class org.apache.flink.runtime.io.disk.iomanager.RequestQueue extends LinkedBlockingQueue<E> implements Serializable
- serialVersionUID:
- 3804115535778471680L
-
Serialized Fields
-
closed
boolean closed
Flag marking this queue as closed.
-
-
-
Package org.apache.flink.runtime.io.network
-
Class org.apache.flink.runtime.io.network.ConnectionID extends Object implements Serializable
- serialVersionUID:
- -8068626194818666857L
-
Serialized Fields
-
address
InetSocketAddress address
-
connectionIndex
int connectionIndex
-
resourceID
ResourceID resourceID
-
-
-
Package org.apache.flink.runtime.io.network.netty.exception
-
Class org.apache.flink.runtime.io.network.netty.exception.LocalTransportException extends TransportException implements Serializable
- serialVersionUID:
- 2366708881288640674L
-
Class org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException extends TransportException implements Serializable
- serialVersionUID:
- 4373615529545893089L
-
Class org.apache.flink.runtime.io.network.netty.exception.TransportException extends IOException implements Serializable
- serialVersionUID:
- 3637820720589866570L
-
Serialized Fields
-
address
SocketAddress address
-
-
-
Package org.apache.flink.runtime.io.network.partition
-
Class org.apache.flink.runtime.io.network.partition.DataSetMetaInfo extends Object implements Serializable
-
Serialized Fields
-
numRegisteredPartitions
int numRegisteredPartitions
-
numTotalPartitions
int numTotalPartitions
-
shuffleDescriptorsOrderByPartitionId
SortedMap<ResultPartitionID,ShuffleDescriptor> shuffleDescriptorsOrderByPartitionId
-
-
-
Class org.apache.flink.runtime.io.network.partition.PartitionException extends IOException implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
partitionId
ResultPartitionID partitionId
-
-
Class org.apache.flink.runtime.io.network.partition.PartitionNotFoundException extends PartitionException implements Serializable
- serialVersionUID:
- 0L
-
Class org.apache.flink.runtime.io.network.partition.ProducerFailedException extends CancelTaskException implements Serializable
- serialVersionUID:
- -1555492656299526395L
-
Class org.apache.flink.runtime.io.network.partition.ResultPartitionID extends Object implements Serializable
- serialVersionUID:
- -902516386203787826L
-
Serialized Fields
-
partitionId
IntermediateResultPartitionID partitionId
-
producerId
ExecutionAttemptID producerId
-
-
Class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet extends IndexRange implements Serializable
-
-
Package org.apache.flink.runtime.io.network.partition.consumer
-
Class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.io.network.partition.consumer.InputGateID extends Object implements Serializable
- serialVersionUID:
- 4613970383536333315L
-
Serialized Fields
-
consumedResultID
IntermediateDataSetID consumedResultID
The ID of the consumed intermediate result. Each input gate consumes partitions of the intermediate result specified by this ID. This ID also identifies the input gate at the consuming task. -
consumerID
ExecutionAttemptID consumerID
-
-
Class org.apache.flink.runtime.io.network.partition.consumer.PartitionConnectionException extends PartitionException implements Serializable
- serialVersionUID:
- 0L
-
-
Package org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageBytesBasedDataIdentifier extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
bytes
byte[] bytes
The bytes data of this identifier. -
hashCode
int hashCode
-
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageInputChannelId extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
inputChannelId
int inputChannelId
-
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStoragePartitionId extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
partitionID
ResultPartitionID partitionID
-
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageSubpartitionId extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
subpartitionId
int subpartitionId
-
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageTopicId extends TieredStorageBytesBasedDataIdentifier implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.AllTieredShuffleMasterSnapshots extends Object implements Serializable
-
Serialized Fields
-
snapshots
Collection<org.apache.flink.api.java.tuple.Tuple2<String,TieredShuffleMasterSnapshot>> snapshots
Snapshots of all tires. For each tier, it is a tuple of (identifier,TieredShuffleMasterSnapshot)
-
-
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.EmptyTieredShuffleMasterSnapshot extends Object implements Serializable
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredInternalShuffleMasterSnapshot extends Object implements Serializable
-
Serialized Fields
-
allTierSnapshots
AllTieredShuffleMasterSnapshots allTierSnapshots
-
shuffleDescriptors
Map<ResultPartitionID,ShuffleDescriptor> shuffleDescriptors
-
-
-
-
Package org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpTierShuffleDescriptor extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.UnknownTierShuffleDescriptor extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
-
Class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierShuffleDescriptor extends Object implements Serializable
-
Serialized Fields
-
partitionId
TieredStoragePartitionId partitionId
-
-
-
-
Package org.apache.flink.runtime.iterative.convergence
-
Class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.jobgraph
-
Class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
inputFormats
Map<OperatorID,org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.InputFormat<?,?>>> inputFormats
-
outputFormats
Map<OperatorID,org.apache.flink.api.common.operators.util.UserCodeWrapper<? extends org.apache.flink.api.common.io.OutputFormat<?>>> outputFormats
-
-
Class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex extends JobVertex implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
formatDescriptions
Map<OperatorID,String> formatDescriptions
-
-
Class org.apache.flink.runtime.jobgraph.IntermediateDataSet extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
consumers
List<JobEdge> consumers
-
distributionPattern
DistributionPattern distributionPattern
-
id
IntermediateDataSetID id
-
isBroadcast
boolean isBroadcast
-
isForward
boolean isForward
-
numJobEdgesToCreate
int numJobEdgesToCreate
The number of job edges that need to be created. -
producer
JobVertex producer
-
resultType
ResultPartitionType resultType
-
-
Class org.apache.flink.runtime.jobgraph.IntermediateDataSetID extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
intermediateDataSetID
IntermediateDataSetID intermediateDataSetID
-
partitionNum
int partitionNum
-
-
Class org.apache.flink.runtime.jobgraph.JobEdge extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
distributionPattern
DistributionPattern distributionPattern
The distribution pattern that should be used for this job edge. -
downstreamSubtaskStateMapper
SubtaskStateMapper downstreamSubtaskStateMapper
The channel rescaler that should be used for this job edge on downstream side. -
interInputsKeysCorrelated
boolean interInputsKeysCorrelated
There are relationships between multiple inputs, if the records corresponding to the same key from one input is split, the corresponding key records from the other inputs must be duplicated (meaning that it must be sent to the downstream nodes where the split data is sent). -
intraInputKeyCorrelated
boolean intraInputKeyCorrelated
Whether records with the same key are correlated and must be sent to the same downstream task to be processed together. -
isBroadcast
boolean isBroadcast
-
isForward
boolean isForward
-
operatorLevelCachingDescription
String operatorLevelCachingDescription
Optional description of the caching inside an operator, to be displayed in the JSON plan. -
preProcessingOperationName
String preProcessingOperationName
Optional name for the pre-processing operation (sort, combining sort, ...), to be displayed in the JSON plan. -
shipStrategyName
String shipStrategyName
Optional name for the data shipping strategy (forward, partition hash, rebalance, ...), to be displayed in the JSON plan. -
source
IntermediateDataSet source
The data set at the source of the edge, may be null if the edge is not yet connected. -
target
JobVertex target
The vertex connected to this edge. -
typeNumber
int typeNumber
-
upstreamSubtaskStateMapper
SubtaskStateMapper upstreamSubtaskStateMapper
The channel rescaler that should be used for this job edge on upstream side.
-
-
Class org.apache.flink.runtime.jobgraph.JobGraph extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
approximateLocalRecovery
boolean approximateLocalRecovery
Whether approximate local recovery is enabled. This flag will be removed together with legacy scheduling strategies. -
classpaths
List<URL> classpaths
List of classpaths required to run this job. -
dynamic
boolean dynamic
-
initialClientHeartbeatTimeout
long initialClientHeartbeatTimeout
-
jobConfiguration
org.apache.flink.configuration.Configuration jobConfiguration
The job configuration attached to this job. -
jobID
org.apache.flink.api.common.JobID jobID
ID of this job. May be set if specific job id is desired (e.g. session management) -
jobName
String jobName
Name of this job. -
jobStatusHooks
List<org.apache.flink.core.execution.JobStatusHook> jobStatusHooks
List of user-defined job status change hooks. -
jobType
JobType jobType
-
savepointRestoreSettings
SavepointRestoreSettings savepointRestoreSettings
Savepoint restore settings. -
serializedExecutionConfig
org.apache.flink.util.SerializedValue<org.apache.flink.api.common.ExecutionConfig> serializedExecutionConfig
Job specific execution config. -
snapshotSettings
JobCheckpointingSettings snapshotSettings
The settings for the job checkpoints. -
taskVertices
Map<JobVertexID,JobVertex> taskVertices
List of task vertices included in this job graph. -
userArtifacts
Map<String,org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry> userArtifacts
Set of custom files required to run this job. -
userJarBlobKeys
List<PermanentBlobKey> userJarBlobKeys
Set of blob keys identifying the JAR files required to run this job. -
userJars
List<org.apache.flink.core.fs.Path> userJars
Set of JAR files required to run this job.
-
-
Class org.apache.flink.runtime.jobgraph.JobResourceRequirements extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
vertexResources
Map<JobVertexID,JobVertexResourceRequirements> vertexResources
-
-
Class org.apache.flink.runtime.jobgraph.JobVertex extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
anyOutputBlocking
boolean anyOutputBlocking
-
coLocationGroup
CoLocationGroupImpl coLocationGroup
The group inside which the vertex subtasks share slots. -
configuration
org.apache.flink.configuration.Configuration configuration
Custom configuration passed to the assigned task at runtime. -
dynamicParallelism
boolean dynamicParallelism
Indicates whether the parallelism of this job vertex is decided dynamically. -
id
JobVertexID id
The ID of the vertex. -
inputs
List<JobEdge> inputs
List of edges with incoming data. One per Reader. -
inputSplitSource
org.apache.flink.core.io.InputSplitSource<?> inputSplitSource
Optionally, a source of input splits. -
intermediateDataSetIdsToConsume
List<IntermediateDataSetID> intermediateDataSetIdsToConsume
The intermediateDataSetId of the cached intermediate dataset that the job vertex consumes. -
invokableClassName
String invokableClassName
The class of the invokable. -
isStoppable
boolean isStoppable
Indicates of this job vertex is stoppable or not. -
maxParallelism
int maxParallelism
Maximum number of subtasks to split this task into a runtime. -
minResources
org.apache.flink.api.common.operators.ResourceSpec minResources
The minimum resource of the vertex. -
name
String name
The name of the vertex. This will be shown in runtime logs and will be in the runtime environment. -
operatorCoordinators
List<org.apache.flink.util.SerializedValue<OperatorCoordinator.Provider>> operatorCoordinators
The list of factories for operator coordinators. -
operatorDescription
String operatorDescription
Optional, the description of the operator, like 'Hash Join', or 'Sorted Group Reduce', to be included in the JSON plan. -
operatorIDs
List<OperatorIDPair> operatorIDs
The IDs of all operators contained in this vertex.The ID pairs are stored depth-first post-order; for the forking chain below the ID's would be stored as [D, E, B, C, A].
A - B - D \ \ C E
This is the same order that operators are stored in the
StreamTask
. -
operatorName
String operatorName
Optional, the name of the operator, such as 'Flat Map' or 'Join', to be included in the JSON plan. -
operatorPrettyName
String operatorPrettyName
Optional, pretty name of the operator, to be displayed in the JSON plan. -
parallelism
int parallelism
Number of subtasks to split this task into at runtime. -
parallelismConfigured
boolean parallelismConfigured
-
preferredResources
org.apache.flink.api.common.operators.ResourceSpec preferredResources
The preferred resource of the vertex. -
resultOptimizerProperties
String resultOptimizerProperties
Optional, the JSON for the optimizer properties of the operator result, to be included in the JSON plan. -
results
Map<IntermediateDataSetID,IntermediateDataSet> results
Produced data sets, one per writer. -
slotSharingGroup
SlotSharingGroup slotSharingGroup
Optionally, a sharing group that allows subtasks from different job vertices to run concurrently in one slot. -
supportsConcurrentExecutionAttempts
boolean supportsConcurrentExecutionAttempts
Indicates whether this job vertex supports multiple attempts of the same subtask executing at the same time.
-
-
Class org.apache.flink.runtime.jobgraph.JobVertexID extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
parallelism
JobVertexResourceRequirements.Parallelism parallelism
-
-
Class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements.Parallelism extends Object implements Serializable
-
Serialized Fields
-
lowerBound
int lowerBound
-
upperBound
int upperBound
-
-
-
Class org.apache.flink.runtime.jobgraph.OperatorID extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings extends Object implements Serializable
- serialVersionUID:
- 87377506900849777L
-
Serialized Fields
-
allowNonRestoredState
boolean allowNonRestoredState
Flag indicating whether non restored state is allowed if the savepoint contains state for an operator that is not part of the job. -
recoveryClaimMode
org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode
-
restorePath
String restorePath
Savepoint restore path.
-
-
-
Package org.apache.flink.runtime.jobgraph.tasks
-
Class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration extends Object implements Serializable
- serialVersionUID:
- 2L
-
Serialized Fields
-
alignedCheckpointTimeout
long alignedCheckpointTimeout
-
checkpointIdOfIgnoredInFlightData
long checkpointIdOfIgnoredInFlightData
-
checkpointInterval
long checkpointInterval
-
checkpointIntervalDuringBacklog
long checkpointIntervalDuringBacklog
-
checkpointRetentionPolicy
CheckpointRetentionPolicy checkpointRetentionPolicy
Settings for what to do with checkpoints when a job finishes. -
checkpointTimeout
long checkpointTimeout
-
enableCheckpointsAfterTasksFinish
boolean enableCheckpointsAfterTasksFinish
-
isExactlyOnce
boolean isExactlyOnce
Flag indicating whether exactly once checkpoint mode has been configured. Iffalse
, 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. -
isUnalignedCheckpointsEnabled
boolean isUnalignedCheckpointsEnabled
-
maxConcurrentCheckpoints
int maxConcurrentCheckpoints
-
minPauseBetweenCheckpoints
long minPauseBetweenCheckpoints
-
tolerableCheckpointFailureNumber
int tolerableCheckpointFailureNumber
-
-
Class org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException extends Exception implements Serializable
- serialVersionUID:
- -8043190713983651548L
-
Class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings extends Object implements Serializable
- serialVersionUID:
- -2593319571078198180L
-
Serialized Fields
-
changelogStateBackendEnabled
org.apache.flink.util.TernaryBoolean changelogStateBackendEnabled
The enable flag for change log state backend, if configured by the user in the job -
checkpointCoordinatorConfiguration
CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration
Contains configuration settings for the CheckpointCoordinator -
defaultCheckpointStorage
org.apache.flink.util.SerializedValue<CheckpointStorage> defaultCheckpointStorage
The default checkpoint storage, if configured by the user in the job -
defaultStateBackend
org.apache.flink.util.SerializedValue<StateBackend> defaultStateBackend
The default state backend, if configured by the user in the job -
masterHooks
org.apache.flink.util.SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks
(Factories for) hooks that are executed on the checkpoint coordinator -
stateBackendUseManagedMemory
org.apache.flink.util.TernaryBoolean stateBackendUseManagedMemory
-
-
-
Package org.apache.flink.runtime.jobmanager
-
Class org.apache.flink.runtime.jobmanager.JobManagerProcessSpec extends CommonProcessMemorySpec<JobManagerFlinkMemory> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.jobmanager.PartitionProducerDisposedException extends Exception implements Serializable
-
-
Package org.apache.flink.runtime.jobmanager.scheduler
-
Class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroupImpl extends Object implements Serializable
- serialVersionUID:
- -2605819490401895297L
-
Class org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException extends JobException implements Serializable
- serialVersionUID:
- -2249953165298717803L
-
Class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
ids
Set<JobVertexID> ids
-
resourceProfile
ResourceProfile resourceProfile
-
slotSharingGroupId
SlotSharingGroupId slotSharingGroupId
-
-
-
Package org.apache.flink.runtime.jobmaster
-
Class org.apache.flink.runtime.jobmaster.AllocatedSlotInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allocationId
AllocationID allocationId
-
slotIndex
int slotIndex
-
-
Class org.apache.flink.runtime.jobmaster.AllocatedSlotReport extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allocatedSlotInfos
Collection<AllocatedSlotInfo> allocatedSlotInfos
The allocated slots in slot pool. -
jobId
org.apache.flink.api.common.JobID jobId
-
-
Class org.apache.flink.runtime.jobmaster.ExecutionGraphException extends JobManagerException implements Serializable
- serialVersionUID:
- -5439002256464886357L
-
Class org.apache.flink.runtime.jobmaster.JMTMRegistrationRejection extends RegistrationResponse.Rejection implements Serializable
- serialVersionUID:
- -5763721635090700901L
-
Serialized Fields
-
reason
String reason
-
-
Class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess extends RegistrationResponse.Success implements Serializable
- serialVersionUID:
- -3528383155961318929L
-
Serialized Fields
-
resourceID
ResourceID resourceID
-
-
Class org.apache.flink.runtime.jobmaster.JobManagerException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- -7290962952242188064L
-
Class org.apache.flink.runtime.jobmaster.JobMasterException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 414268039380255248L
-
Class org.apache.flink.runtime.jobmaster.JobMasterId extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- -933276753644003754L
-
Class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess extends RegistrationResponse.Success implements Serializable
- serialVersionUID:
- 5577641250204140415L
-
Serialized Fields
-
resourceManagerId
ResourceManagerId resourceManagerId
-
resourceManagerResourceId
ResourceID resourceManagerResourceId
-
-
Class org.apache.flink.runtime.jobmaster.JobNotFinishedException extends JobException implements Serializable
- serialVersionUID:
- 611413276562570622L
-
Class org.apache.flink.runtime.jobmaster.JobResult extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
accumulatorResults
Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> accumulatorResults
-
applicationStatus
ApplicationStatus applicationStatus
-
jobId
org.apache.flink.api.common.JobID jobId
-
netRuntime
long netRuntime
-
serializedThrowable
org.apache.flink.util.SerializedThrowable serializedThrowable
Stores the cause of the job failure, ornull
if the job finished successfully.
-
-
Class org.apache.flink.runtime.jobmaster.SerializedInputSplit extends Object implements Serializable
- serialVersionUID:
- -2063021844254152064L
-
Serialized Fields
-
inputSplitData
byte[] inputSplitData
-
-
Class org.apache.flink.runtime.jobmaster.SlotRequestId extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- -6072105912250154283L
-
Class org.apache.flink.runtime.jobmaster.TaskManagerRegistrationInformation extends Object implements Serializable
- serialVersionUID:
- 1767026305134276540L
-
Serialized Fields
-
taskManagerRpcAddress
String taskManagerRpcAddress
-
taskManagerSession
UUID taskManagerSession
-
unresolvedTaskManagerLocation
UnresolvedTaskManagerLocation unresolvedTaskManagerLocation
-
-
-
Package org.apache.flink.runtime.jobmaster.event
-
Class org.apache.flink.runtime.jobmaster.event.ExecutionJobVertexFinishedEvent extends Object implements Serializable
-
Serialized Fields
-
resultInfo
Map<IntermediateDataSetID,BlockingResultInfo> resultInfo
-
vertexId
JobVertexID vertexId
-
-
-
Class org.apache.flink.runtime.jobmaster.event.ExecutionJobVertexInitializedEvent extends Object implements Serializable
-
Serialized Fields
-
jobVertexId
JobVertexID jobVertexId
-
jobVertexInputInfos
Map<IntermediateDataSetID,JobVertexInputInfo> jobVertexInputInfos
-
parallelism
int parallelism
-
-
-
Class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent extends Object implements Serializable
-
Serialized Fields
-
executionAttemptId
ExecutionAttemptID executionAttemptId
-
ioMetrics
IOMetrics ioMetrics
-
taskManagerLocation
TaskManagerLocation taskManagerLocation
-
userAccumulators
Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> userAccumulators
-
-
-
Class org.apache.flink.runtime.jobmaster.event.ExecutionVertexResetEvent extends Object implements Serializable
-
Serialized Fields
-
executionVertexIds
List<ExecutionVertexID> executionVertexIds
-
-
-
-
Package org.apache.flink.runtime.leaderelection
-
Class org.apache.flink.runtime.leaderelection.LeaderElectionException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.leaderelection.LeaderInformation extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.leaderelection.LeadershipLostException extends LeaderElectionException implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.leaderretrieval
-
Class org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 42L
-
-
Package org.apache.flink.runtime.memory
-
Class org.apache.flink.runtime.memory.MemoryAllocationException extends Exception implements Serializable
- serialVersionUID:
- -403983866457947012L
-
Class org.apache.flink.runtime.memory.MemoryReservationException extends Exception implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.messages
-
Class org.apache.flink.runtime.messages.Acknowledge extends Object implements Serializable
- serialVersionUID:
- 7808628311617273755L
-
Serialization Methods
-
readResolve
protected Object readResolve() throws ObjectStreamException
Read resolve to preserve the singleton object property. (per best practices, this should have visibility 'protected')- Throws:
ObjectStreamException
-
-
Class org.apache.flink.runtime.messages.FlinkJobNotFoundException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 2294698055059659025L
-
Class org.apache.flink.runtime.messages.FlinkJobTerminatedWithoutCancellationException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 2294698055059659025L
-
Serialized Fields
-
jobStatus
org.apache.flink.api.common.JobStatus jobStatus
-
-
Class org.apache.flink.runtime.messages.TaskBackPressureResponse extends Object implements Serializable
- serialVersionUID:
- -4786454630050578031L
-
Serialized Fields
-
backPressureRatio
double backPressureRatio
-
executionAttemptID
ExecutionAttemptID executionAttemptID
-
requestId
int requestId
-
-
Class org.apache.flink.runtime.messages.TaskThreadInfoResponse extends Object implements Serializable
- serialVersionUID:
- -4786454630050578031L
-
Serialized Fields
-
samples
Map<ExecutionAttemptID,Collection<ThreadInfoSample>> samples
-
-
Class org.apache.flink.runtime.messages.ThreadInfoSample extends Object implements Serializable
-
Serialized Fields
-
stackTrace
StackTraceElement[] stackTrace
-
threadState
Thread.State threadState
-
-
-
-
Package org.apache.flink.runtime.messages.checkpoint
-
Class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage extends Object implements Serializable
- serialVersionUID:
- 186780414819428178L
-
Serialized Fields
-
checkpointId
long checkpointId
The ID of the checkpoint that this message coordinates -
job
org.apache.flink.api.common.JobID job
The job to which this message belongs -
taskExecutionId
ExecutionAttemptID taskExecutionId
The task execution that is source/target of the checkpoint message
-
-
Class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint extends AbstractCheckpointMessage implements Serializable
- serialVersionUID:
- -7606214777192401493L
-
Serialized Fields
-
checkpointMetrics
CheckpointMetrics checkpointMetrics
-
subtaskState
TaskStateSnapshot subtaskState
-
-
Class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint extends AbstractCheckpointMessage implements Serializable
- serialVersionUID:
- 2094094662279578953L
-
Serialized Fields
-
serializedCheckpointException
SerializedCheckpointException serializedCheckpointException
The serialized reason why the checkpoint was declined.
-
-
Class org.apache.flink.runtime.messages.checkpoint.SerializedCheckpointException extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
checkpointFailureReason
CheckpointFailureReason checkpointFailureReason
-
serializedThrowable
org.apache.flink.util.SerializedThrowable serializedThrowable
-
-
-
Package org.apache.flink.runtime.messages.webmonitor
-
Class org.apache.flink.runtime.messages.webmonitor.ClusterOverview extends JobsOverview implements Serializable
- serialVersionUID:
- -729861859715105265L
-
Serialized Fields
-
numSlotsAvailable
int numSlotsAvailable
-
numSlotsFreeAndBlocked
int numSlotsFreeAndBlocked
-
numSlotsTotal
int numSlotsTotal
-
numTaskManagersBlocked
int numTaskManagersBlocked
-
numTaskManagersConnected
int numTaskManagersConnected
-
-
Class org.apache.flink.runtime.messages.webmonitor.JobDetails extends Object implements Serializable
- serialVersionUID:
- -3391462110304948766L
-
Serialized Fields
-
currentExecutionAttempts
Map<String,Map<Integer,JobDetails.CurrentAttempts>> currentExecutionAttempts
The map holds the attempt number of the current execution attempt in the Execution, which is considered as the representing execution for the subtask of the vertex. The keys and values are JobVertexID -> SubtaskIndex -> CurrenAttempts info.The field is excluded from the json. Any usage from the web UI and the history server is not allowed.
-
duration
long duration
-
endTime
long endTime
-
jobId
org.apache.flink.api.common.JobID jobId
-
jobName
String jobName
-
lastUpdateTime
long lastUpdateTime
-
numTasks
int numTasks
-
pendingOperators
int pendingOperators
-
startTime
long startTime
-
status
org.apache.flink.api.common.JobStatus status
-
tasksPerState
int[] tasksPerState
-
-
Class org.apache.flink.runtime.messages.webmonitor.JobDetails.CurrentAttempts extends Object implements Serializable
-
Class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview extends Object implements Serializable
- serialVersionUID:
- -3699051943490133183L
-
Serialized Fields
-
jobsWithStatus
Collection<JobIdsWithStatusOverview.JobIdWithStatus> jobsWithStatus
-
-
Class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus extends Object implements Serializable
- serialVersionUID:
- -499449819268733026L
-
Serialized Fields
-
jobId
org.apache.flink.api.common.JobID jobId
-
jobStatus
org.apache.flink.api.common.JobStatus jobStatus
-
-
Class org.apache.flink.runtime.messages.webmonitor.JobsOverview extends Object implements Serializable
- serialVersionUID:
- -3699051943490133183L
-
Serialized Fields
-
numJobsCancelled
int numJobsCancelled
-
numJobsFailed
int numJobsFailed
-
numJobsFinished
int numJobsFinished
-
numJobsRunningOrPending
int numJobsRunningOrPending
-
-
Class org.apache.flink.runtime.messages.webmonitor.JobStatusInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jobStatus
org.apache.flink.api.common.JobStatus jobStatus
-
-
Class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails extends Object implements Serializable
- serialVersionUID:
- -1526236139616019127L
-
Serialized Fields
-
jobs
Collection<JobDetails> jobs
-
-
Class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails extends Object implements Serializable
- serialVersionUID:
- 5208137000412166747L
-
Serialized Fields
-
includeFinished
boolean includeFinished
-
includeRunning
boolean includeRunning
-
-
Class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview extends Object implements Serializable
- serialVersionUID:
- 3052933564788843275L
-
Serialization Methods
-
readResolve
private Object readResolve()
Preserve the singleton property by returning the singleton instance
-
-
Class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview extends Object implements Serializable
- serialVersionUID:
- 3052933564788843275L
-
Serialization Methods
-
readResolve
private Object readResolve()
Preserve the singleton property by returning the singleton instance
-
-
Class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview extends Object implements Serializable
- serialVersionUID:
- 3052933564788843275L
-
Serialization Methods
-
readResolve
private Object readResolve()
Preserve the singleton property by returning the singleton instance
-
-
-
Package org.apache.flink.runtime.metrics
-
Class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
descriptiveStatistics
org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram.CircularDoubleArray descriptiveStatistics
-
-
Class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics extends org.apache.flink.metrics.HistogramStatistics implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
statisticsSummary
org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics.CommonMetricsSnapshot statisticsSummary
-
-
Class org.apache.flink.runtime.metrics.ThresholdMeter.ThresholdExceedException extends RuntimeException implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.metrics.dump
-
Class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult extends Object implements Serializable
- serialVersionUID:
- 6928770855951536906L
-
Serialized Fields
-
numCounters
int numCounters
-
numGauges
int numGauges
-
numHistograms
int numHistograms
-
numMeters
int numMeters
-
serializedCounters
byte[] serializedCounters
-
serializedGauges
byte[] serializedGauges
-
serializedHistograms
byte[] serializedHistograms
-
serializedMeters
byte[] serializedMeters
-
-
-
Package org.apache.flink.runtime.operators.chaining
-
Class org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException extends RuntimeException implements Serializable
- serialVersionUID:
- -7966910518892776903L
-
-
Package org.apache.flink.runtime.operators.coordination
-
Class org.apache.flink.runtime.operators.coordination.AcknowledgeCheckpointEvent extends Object implements Serializable
-
Serialized Fields
-
checkpointId
long checkpointId
The ID of the checkpoint that this event is related to.
-
-
-
Class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator.Provider extends Object implements Serializable
- serialVersionUID:
- 3002837631612629071L
-
Serialized Fields
-
operatorID
OperatorID operatorID
-
-
Class org.apache.flink.runtime.operators.coordination.TaskNotRunningException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.operators.udf
-
Class org.apache.flink.runtime.operators.udf.AssignRangeIndex extends org.apache.flink.api.common.functions.RichMapPartitionFunction<IN,org.apache.flink.api.java.tuple.Tuple2<Integer,IN>> implements Serializable
-
Serialized Fields
-
typeComparator
org.apache.flink.api.common.typeutils.TypeComparatorFactory<IN> typeComparator
-
-
-
Class org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder extends org.apache.flink.api.common.functions.RichMapPartitionFunction<T,Object[][]> implements Serializable
-
Serialized Fields
-
comparatorFactory
org.apache.flink.api.common.typeutils.TypeComparatorFactory<T> comparatorFactory
-
parallelism
int parallelism
-
-
-
Class org.apache.flink.runtime.operators.udf.RemoveRangeIndex extends Object implements Serializable
-
-
Package org.apache.flink.runtime.operators.util
-
Class org.apache.flink.runtime.operators.util.CorruptConfigurationException extends RuntimeException implements Serializable
- serialVersionUID:
- 854450995262666207L
-
Class org.apache.flink.runtime.operators.util.TaskConfig extends Object implements Serializable
- serialVersionUID:
- -2498884325640066272L
-
Serialized Fields
-
config
org.apache.flink.configuration.Configuration config
-
-
-
Package org.apache.flink.runtime.persistence
-
Class org.apache.flink.runtime.persistence.IntegerResourceVersion extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
value
int value
-
-
Class org.apache.flink.runtime.persistence.PossibleInconsistentStateException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 364105635349022882L
-
Class org.apache.flink.runtime.persistence.StateHandleStore.AlreadyExistException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.persistence.StateHandleStore.NotExistException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.persistence.StringResourceVersion extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
value
String value
-
-
-
Package org.apache.flink.runtime.query
-
Class org.apache.flink.runtime.query.KvStateLocation extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jobId
org.apache.flink.api.common.JobID jobId
JobID the KvState instances belong to. -
jobVertexId
JobVertexID jobVertexId
JobVertexID the KvState instances belong to. -
kvStateAddresses
InetSocketAddress[] kvStateAddresses
Server address for each KvState instance where array index corresponds to key group index. -
kvStateIds
org.apache.flink.queryablestate.KvStateID[] kvStateIds
IDs for each KvState instance where array index corresponds to key group index. -
numKeyGroups
int numKeyGroups
Number of key groups of the operator the KvState instances belong to. -
numRegisteredKeyGroups
int numRegisteredKeyGroups
Current number of registered key groups. -
registrationName
String registrationName
Name under which the KvState instances have been registered.
-
-
Class org.apache.flink.runtime.query.UnknownKvStateLocation extends Exception implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.registration
-
Class org.apache.flink.runtime.registration.RegistrationResponse extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.registration.RegistrationResponse.Failure extends RegistrationResponse implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
reason
org.apache.flink.util.SerializedThrowable reason
The failure reason.
-
-
Class org.apache.flink.runtime.registration.RegistrationResponse.Rejection extends RegistrationResponse implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.registration.RegistrationResponse.Success extends RegistrationResponse implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.resourcemanager
-
Class org.apache.flink.runtime.resourcemanager.ResourceManagerId extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- -6042820142662137374L
-
Class org.apache.flink.runtime.resourcemanager.ResourceOverview extends Object implements Serializable
- serialVersionUID:
- 7618746920569224557L
-
Serialized Fields
-
freeResource
ResourceProfile freeResource
-
numberBlockedFreeSlots
int numberBlockedFreeSlots
-
numberBlockedTaskManagers
int numberBlockedTaskManagers
-
numberFreeSlots
int numberFreeSlots
-
numberRegisteredSlots
int numberRegisteredSlots
-
numberTaskManagers
int numberTaskManagers
-
totalResource
ResourceProfile totalResource
-
-
Class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration extends Object implements Serializable
- serialVersionUID:
- -5727832919954047964L
-
Serialized Fields
-
dataPort
int dataPort
Port used for data communication between TaskExecutors. -
defaultSlotResourceProfile
ResourceProfile defaultSlotResourceProfile
The default resource profile for slots requested with unknown resource requirements. -
hardwareDescription
HardwareDescription hardwareDescription
HardwareDescription of the registering TaskExecutor. -
jmxPort
int jmxPort
Port used for JMX RMI. -
memoryConfiguration
TaskExecutorMemoryConfiguration memoryConfiguration
Memory configuration of the registering TaskExecutor. -
nodeId
String nodeId
ID of the node where the TaskManager is located on. In Yarn and Native Kubernetes mode, this value will be set by resource manager when launch this TaskManager(via the config optionTaskManagerOptionsInternal.TASK_MANAGER_NODE_ID
). In other modes, this value will be the external address of the TaskManager. -
resourceId
ResourceID resourceId
The resource ID of the TaskExecutor that registers. -
taskExecutorAddress
String taskExecutorAddress
The address of the TaskExecutor that registers. -
totalResourceProfile
ResourceProfile totalResourceProfile
The task executor total resource profile.
-
-
Class org.apache.flink.runtime.resourcemanager.TaskManagerInfoWithSlots extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allocatedSlots
Collection<SlotInfo> allocatedSlots
-
taskManagerInfo
TaskManagerInfo taskManagerInfo
-
-
Class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cpuCores
org.apache.flink.api.common.resources.CPUResource cpuCores
-
extendedResources
Map<String,org.apache.flink.api.common.resources.ExternalResource> extendedResources
-
managedMemSize
org.apache.flink.configuration.MemorySize managedMemSize
-
networkMemSize
org.apache.flink.configuration.MemorySize networkMemSize
-
numSlots
int numSlots
-
taskHeapSize
org.apache.flink.configuration.MemorySize taskHeapSize
-
taskOffHeapSize
org.apache.flink.configuration.MemorySize taskOffHeapSize
-
-
-
Package org.apache.flink.runtime.resourcemanager.exceptions
-
Class org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- -5503307426519195160L
-
Class org.apache.flink.runtime.resourcemanager.exceptions.UnfulfillableSlotRequestException extends ResourceManagerException implements Serializable
- serialVersionUID:
- 4453490263648758730L
-
Class org.apache.flink.runtime.resourcemanager.exceptions.UnknownTaskExecutorException extends ResourceManagerException implements Serializable
- serialVersionUID:
- -950571714195353733L
-
-
Package org.apache.flink.runtime.resourcemanager.slotmanager
-
Class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerId extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException extends ResourceManagerException implements Serializable
-
-
Package org.apache.flink.runtime.rest
-
Class org.apache.flink.runtime.rest.ConnectionClosedException extends ConnectionException implements Serializable
- serialVersionUID:
- 3802002501688542472L
-
Class org.apache.flink.runtime.rest.ConnectionException extends IOException implements Serializable
- serialVersionUID:
- -8483133957344173698L
-
Class org.apache.flink.runtime.rest.ConnectionIdleException extends ConnectionException implements Serializable
- serialVersionUID:
- 5103778538635217293L
-
Class org.apache.flink.runtime.rest.NotFoundException extends RestHandlerException implements Serializable
- serialVersionUID:
- -4036006746423754639L
-
Class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator extends Object implements Serializable
- serialVersionUID:
- 2388466767835547926L
-
Class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator extends Object implements Serializable
- serialVersionUID:
- 8550835445193437027L
-
-
Package org.apache.flink.runtime.rest.handler
-
Class org.apache.flink.runtime.rest.handler.HandlerRequestException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 7310878739304006028L
-
Class org.apache.flink.runtime.rest.handler.RestHandlerException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- -1358206297964070876L
-
Serialized Fields
-
loggingBehavior
RestHandlerException.LoggingBehavior loggingBehavior
-
responseCode
int responseCode
-
-
-
Package org.apache.flink.runtime.rest.handler.async
-
Class org.apache.flink.runtime.rest.handler.async.OperationKey extends Object implements Serializable
- serialVersionUID:
- 6138473450686379255L
-
Serialized Fields
-
triggerId
TriggerId triggerId
-
-
Class org.apache.flink.runtime.rest.handler.async.OperationResult extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
result
R result
-
status
OperationResultStatus status
-
throwable
Throwable throwable
-
-
-
Package org.apache.flink.runtime.rest.handler.dataset
-
Class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers.SerializableVoid extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.rest.handler.job
-
Class org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey extends OperationKey implements Serializable
- serialVersionUID:
- -4907777251835275859L
-
Serialized Fields
-
jobId
org.apache.flink.api.common.JobID jobId
-
-
-
Package org.apache.flink.runtime.rest.handler.legacy.messages
-
Class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion extends ClusterOverview implements Serializable
- serialVersionUID:
- 5000058311783413216L
-
-
Package org.apache.flink.runtime.rest.handler.util
-
Class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics extends IOMetrics implements Serializable
- serialVersionUID:
- -5460777634971381737L
-
Serialized Fields
-
numBytesInComplete
boolean numBytesInComplete
-
numBytesOutComplete
boolean numBytesOutComplete
-
numRecordsInComplete
boolean numRecordsInComplete
-
numRecordsOutComplete
boolean numRecordsOutComplete
-
-
-
Package org.apache.flink.runtime.rest.messages
-
Class org.apache.flink.runtime.rest.messages.ConfigurationInfo extends ArrayList<ConfigurationInfoEntry> implements Serializable
- serialVersionUID:
- -1170348873871206964L
-
Class org.apache.flink.runtime.rest.messages.ConversionException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- -3994595267407963335L
-
Class org.apache.flink.runtime.rest.messages.JobConfigInfo.Deserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<JobConfigInfo> implements Serializable
- serialVersionUID:
- -3580088509877177213L
-
Class org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<JobConfigInfo> implements Serializable
- serialVersionUID:
- -1551666039618928811L
-
Class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Deserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<JobPlanInfo.RawJson> implements Serializable
- serialVersionUID:
- -3580088509877177213L
-
Class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<JobPlanInfo.RawJson> implements Serializable
- serialVersionUID:
- -1551666039618928811L
-
Class org.apache.flink.runtime.rest.messages.LogInfo extends Object implements Serializable
- serialVersionUID:
- -7371944349031708629L
-
Serialized Fields
-
mtime
long mtime
-
name
String name
-
size
long size
-
-
Class org.apache.flink.runtime.rest.messages.LogListInfo extends Object implements Serializable
- serialVersionUID:
- 7531494560450830517L
-
Serialized Fields
-
logInfos
Collection<LogInfo> logInfos
-
-
Class org.apache.flink.runtime.rest.messages.ProfilingInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
duration
Long duration
-
finishedTime
Long finishedTime
-
message
String message
-
mode
ProfilingInfo.ProfilingMode mode
-
outputFile
String outputFile
-
status
ProfilingInfo.ProfilingStatus status
-
triggerTime
Long triggerTime
-
-
Class org.apache.flink.runtime.rest.messages.ProfilingInfoList extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
profilingInfos
Collection<ProfilingInfo> profilingInfos
-
-
Class org.apache.flink.runtime.rest.messages.ResourceProfileInfo extends Object implements Serializable
- serialVersionUID:
- 2286586486998901098L
-
Class org.apache.flink.runtime.rest.messages.ThreadDumpInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
threadInfos
Collection<ThreadDumpInfo.ThreadInfo> threadInfos
-
-
Class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.TriggerId extends org.apache.flink.util.AbstractID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<TriggerId> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<TriggerId> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.rest.messages.checkpoints
-
Class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<CheckpointConfigInfo.ProcessingMode> implements Serializable
-
Class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<CheckpointConfigInfo.ProcessingMode> implements Serializable
-
-
Package org.apache.flink.runtime.rest.messages.job.metrics
-
Class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Deserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<AggregatedMetricsResponseBody> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<AggregatedMetricsResponseBody> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Deserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<MetricCollectionResponseBody> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<MetricCollectionResponseBody> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.rest.messages.json
-
Class org.apache.flink.runtime.rest.messages.json.JobIDDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<org.apache.flink.api.common.JobID> implements Serializable
- serialVersionUID:
- -130167416771003559L
-
Class org.apache.flink.runtime.rest.messages.json.JobIDSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<org.apache.flink.api.common.JobID> implements Serializable
- serialVersionUID:
- -6598593519161574611L
-
Class org.apache.flink.runtime.rest.messages.json.JobResultDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<JobResult> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jobIdDeserializer
JobIDDeserializer jobIdDeserializer
-
serializedThrowableDeserializer
SerializedThrowableDeserializer serializedThrowableDeserializer
-
serializedValueDeserializer
SerializedValueDeserializer serializedValueDeserializer
-
-
Class org.apache.flink.runtime.rest.messages.json.JobResultSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<JobResult> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jobIdSerializer
JobIDSerializer jobIdSerializer
-
serializedThrowableSerializer
SerializedThrowableSerializer serializedThrowableSerializer
-
serializedValueSerializer
SerializedValueSerializer serializedValueSerializer
-
-
Class org.apache.flink.runtime.rest.messages.json.JobVertexIDDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<JobVertexID> implements Serializable
- serialVersionUID:
- 3051901462549718924L
-
Class org.apache.flink.runtime.rest.messages.json.JobVertexIDKeySerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<JobVertexID> implements Serializable
- serialVersionUID:
- 2970050507628933522L
-
Class org.apache.flink.runtime.rest.messages.json.JobVertexIDSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<JobVertexID> implements Serializable
- serialVersionUID:
- -2339350570828548335L
-
Class org.apache.flink.runtime.rest.messages.json.RawJsonDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<String> implements Serializable
- serialVersionUID:
- -4089499607872996396L
-
Class org.apache.flink.runtime.rest.messages.json.ResourceIDDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<ResourceID> implements Serializable
- serialVersionUID:
- -9058463293913469849L
-
Class org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<ResourceID> implements Serializable
- serialVersionUID:
- 5798852092159615938L
-
Class org.apache.flink.runtime.rest.messages.json.SerializedThrowableDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<org.apache.flink.util.SerializedThrowable> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<org.apache.flink.util.SerializedThrowable> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<org.apache.flink.util.SerializedValue<?>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<org.apache.flink.util.SerializedValue<?>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDDeserializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.deser.std.StdDeserializer<SlotSharingGroupId> implements Serializable
- serialVersionUID:
- -2908308366715321301L
-
Class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDSerializer extends org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ser.std.StdSerializer<SlotSharingGroupId> implements Serializable
- serialVersionUID:
- -4052148694985726120L
-
-
Package org.apache.flink.runtime.rest.messages.taskmanager
-
Class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jobId
org.apache.flink.api.common.JobID jobId
-
resource
ResourceProfileInfo resource
-
-
Class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo extends TaskManagerInfo implements Serializable
-
Serialized Fields
-
allocatedSlots
Collection<SlotInfo> allocatedSlots
-
taskManagerMetrics
TaskManagerMetricsInfo taskManagerMetrics
-
-
-
Class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
address
String address
-
blocked
boolean blocked
-
dataPort
int dataPort
-
freeResource
ResourceProfileInfo freeResource
-
hardwareDescription
HardwareDescription hardwareDescription
-
jmxPort
int jmxPort
-
lastHeartbeat
long lastHeartbeat
-
memoryConfiguration
TaskExecutorMemoryConfiguration memoryConfiguration
-
numberAvailableSlots
int numberAvailableSlots
-
numberSlots
int numberSlots
-
resourceId
ResourceID resourceId
-
totalResource
ResourceProfileInfo totalResource
-
-
-
Package org.apache.flink.runtime.rest.util
-
Class org.apache.flink.runtime.rest.util.RestClientException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 937914622022344423L
-
Serialized Fields
-
responseCode
int responseCode
-
-
-
Package org.apache.flink.runtime.scheduler
-
Class org.apache.flink.runtime.scheduler.ClusterDatasetCorruptedException extends JobException implements Serializable
-
Serialized Fields
-
corruptedClusterDatasetIds
List<IntermediateDataSetID> corruptedClusterDatasetIds
-
-
-
Class org.apache.flink.runtime.scheduler.ExecutionGraphInfo extends Object implements Serializable
- serialVersionUID:
- -6134203195124124202L
-
Serialized Fields
-
exceptionHistory
Iterable<RootExceptionHistoryEntry> exceptionHistory
-
executionGraph
ArchivedExecutionGraph executionGraph
-
-
-
Package org.apache.flink.runtime.scheduler.exceptionhistory
-
Class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry extends ErrorInfo implements Serializable
- serialVersionUID:
- -3855285510064263701L
-
Serialized Fields
-
failingTaskName
String failingTaskName
-
failureLabels
Map<String,String> failureLabels
Labels associated with the failure, set as soon as failureLabelsFuture is completed. -
taskManagerLocation
ExceptionHistoryEntry.ArchivedTaskManagerLocation taskManagerLocation
-
-
Class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry.ArchivedTaskManagerLocation extends Object implements Serializable
- serialVersionUID:
- -6596854145482446664L
-
Serialized Fields
-
addressStr
String addressStr
-
fqdnHostname
String fqdnHostname
-
hostname
String hostname
-
port
int port
-
resourceID
ResourceID resourceID
-
-
Class org.apache.flink.runtime.scheduler.exceptionhistory.RootExceptionHistoryEntry extends ExceptionHistoryEntry implements Serializable
- serialVersionUID:
- -7647332765867297434L
-
Serialized Fields
-
concurrentExceptions
Collection<ExceptionHistoryEntry> concurrentExceptions
-
-
-
Package org.apache.flink.runtime.scheduler.stopwithsavepoint
-
Class org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointStoppingException extends org.apache.flink.util.FlinkException implements Serializable
-
Serialized Fields
-
savepointPath
String savepointPath
-
-
-
-
Package org.apache.flink.runtime.scheduler.strategy
-
Class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jobVertexId
JobVertexID jobVertexId
-
subtaskIndex
int subtaskIndex
-
-
-
Package org.apache.flink.runtime.security
-
Class org.apache.flink.runtime.security.NoMatchSecurityFactoryException extends RuntimeException implements Serializable
-
Class org.apache.flink.runtime.security.SecurityContextInitializeException extends GeneralSecurityException implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.security.modules
-
Class org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException extends GeneralSecurityException implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.security.token
-
Class org.apache.flink.runtime.security.token.DelegationTokenContainer extends Object implements Serializable
-
-
Package org.apache.flink.runtime.shuffle
-
Class org.apache.flink.runtime.shuffle.DefaultPartitionWithMetrics extends Object implements Serializable
-
Serialized Fields
-
partitionMetrics
ShuffleMetrics partitionMetrics
-
shuffleDescriptor
ShuffleDescriptor shuffleDescriptor
-
-
-
Class org.apache.flink.runtime.shuffle.DefaultShuffleMetrics extends Object implements Serializable
-
Serialized Fields
-
partitionBytes
ResultPartitionBytes partitionBytes
-
-
-
Class org.apache.flink.runtime.shuffle.EmptyShuffleMasterSnapshot extends Object implements Serializable
-
Class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor extends Object implements Serializable
- serialVersionUID:
- 852181945034989215L
-
Serialized Fields
-
partitionConnectionInfo
NettyShuffleDescriptor.PartitionConnectionInfo partitionConnectionInfo
-
producerLocation
ResourceID producerLocation
-
resultPartitionID
ResultPartitionID resultPartitionID
-
tierShuffleDescriptors
List<TierShuffleDescriptor> tierShuffleDescriptors
-
-
Class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.NetworkPartitionConnectionInfo extends Object implements Serializable
- serialVersionUID:
- 5992534320110743746L
-
Serialized Fields
-
address
InetSocketAddress address
-
connectionIndex
int connectionIndex
-
-
Class org.apache.flink.runtime.shuffle.PartitionDescriptor extends Object implements Serializable
- serialVersionUID:
- 6343547936086963705L
-
Serialized Fields
-
connectionIndex
int connectionIndex
Connection index to identify this partition of intermediate result. -
isAllToAllDistribution
boolean isAllToAllDistribution
Whether the distribution pattern of the intermediate result isDistributionPattern.ALL_TO_ALL
. -
isBroadcast
boolean isBroadcast
Whether the intermediate result is a broadcast result. -
isNumberOfPartitionConsumerUndefined
boolean isNumberOfPartitionConsumerUndefined
-
numberOfSubpartitions
int numberOfSubpartitions
The number of subpartitions. -
partitionId
IntermediateResultPartitionID partitionId
The ID of the partition. -
partitionType
ResultPartitionType partitionType
The type of the partition. -
resultId
IntermediateDataSetID resultId
The ID of the result this partition belongs to. -
totalNumberOfPartitions
int totalNumberOfPartitions
The total number of partitions for the result.
-
-
Class org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor extends Object implements Serializable
- serialVersionUID:
- -4001330825983412431L
-
Serialized Fields
-
resultPartitionID
ResultPartitionID resultPartitionID
-
-
-
Package org.apache.flink.runtime.slots
-
Class org.apache.flink.runtime.slots.ResourceRequirement extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
numberOfRequiredSlots
int numberOfRequiredSlots
-
resourceProfile
ResourceProfile resourceProfile
-
-
Class org.apache.flink.runtime.slots.ResourceRequirements extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jobId
org.apache.flink.api.common.JobID jobId
-
resourceRequirements
Collection<ResourceRequirement> resourceRequirements
-
targetAddress
String targetAddress
-
-
-
Package org.apache.flink.runtime.source.coordinator
-
Class org.apache.flink.runtime.source.coordinator.SourceCoordinatorProvider extends RecreateOnResetOperatorCoordinator.Provider implements Serializable
- serialVersionUID:
- -1921681440009738462L
-
Serialized Fields
-
alignmentParams
org.apache.flink.api.common.eventtime.WatermarkAlignmentParams alignmentParams
-
coordinatorListeningID
String coordinatorListeningID
-
numWorkerThreads
int numWorkerThreads
-
operatorName
String operatorName
-
source
org.apache.flink.api.connector.source.Source<?,SplitT extends org.apache.flink.api.connector.source.SourceSplit,?> source
-
-
-
Package org.apache.flink.runtime.source.event
-
Class org.apache.flink.runtime.source.event.AddSplitEvent extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
serializerVersion
int serializerVersion
-
splits
ArrayList<byte[]> splits
-
-
Class org.apache.flink.runtime.source.event.IsProcessingBacklogEvent extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
isProcessingBacklog
boolean isProcessingBacklog
-
-
Class org.apache.flink.runtime.source.event.NoMoreSplitsEvent extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.source.event.ReaderRegistrationEvent extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
location
String location
-
subtaskId
int subtaskId
-
-
Class org.apache.flink.runtime.source.event.ReportedWatermarkEvent extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
watermark
long watermark
-
-
Class org.apache.flink.runtime.source.event.RequestSplitEvent extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
hostName
String hostName
-
-
Class org.apache.flink.runtime.source.event.SourceEventWrapper extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
sourceEvent
org.apache.flink.api.connector.source.SourceEvent sourceEvent
-
-
Class org.apache.flink.runtime.source.event.WatermarkAlignmentEvent extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
maxWatermark
long maxWatermark
-
-
-
Package org.apache.flink.runtime.state
-
Class org.apache.flink.runtime.state.AbstractChannelStateHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
delegate
StreamStateHandle delegate
-
info
Info info
-
offsets
List<Long> offsets
-
size
long size
-
subtaskIndex
int subtaskIndex
The original subtask index before rescaling recovery.
-
-
Class org.apache.flink.runtime.state.AbstractIncrementalStateHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
backendIdentifier
UUID backendIdentifier
UUID to identify the backend which created this state handle. This is in creating the key for theSharedStateRegistry
. -
checkpointId
long checkpointId
The checkpoint Id. -
keyGroupRange
KeyGroupRange keyGroupRange
The key-group range covered by this state handle. -
metaStateHandle
StreamStateHandle metaStateHandle
Primary meta data state of the incremental checkpoint. -
sharedState
List<IncrementalKeyedStateHandle.HandleAndLocalPath> sharedState
Shared state in the incremental checkpoint. -
stateHandleId
StateHandleID stateHandleId
Unique id for this state handle.
-
-
Class org.apache.flink.runtime.state.AbstractManagedMemoryStateBackend extends AbstractStateBackend implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.AbstractStateBackend extends Object implements Serializable
- serialVersionUID:
- 4620415814639230247L
-
Serialized Fields
-
latencyTrackingConfigBuilder
LatencyTrackingStateConfig.Builder latencyTrackingConfigBuilder
-
-
Class org.apache.flink.runtime.state.ArrayListSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<ArrayList<T>> implements Serializable
- serialVersionUID:
- 1119562170939152304L
-
Serialized Fields
-
elementSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<T> elementSerializer
-
-
Class org.apache.flink.runtime.state.BackendBuildingException extends IOException implements Serializable
-
Class org.apache.flink.runtime.state.ChainedStateHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
operatorStateHandles
List<? extends T extends StateObject> operatorStateHandles
The state handles for all operators in the chain
-
-
Class org.apache.flink.runtime.state.CheckpointStorageLocationReference extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readResolve
protected final Object readResolve() throws ObjectStreamException
readResolve() preserves the singleton property of the default value.- Throws:
ObjectStreamException
-
-
Serialized Fields
-
encodedReference
byte[] encodedReference
The encoded location reference. null indicates the default location.
-
-
Class org.apache.flink.runtime.state.DirectoryStateHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
directorySize
long directorySize
(Optional) Size of the directory, used for metrics. Can be 0 if unknown or empty. -
directoryString
String directoryString
The path that describes the directory, as a string, to be serializable.
-
-
Class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath extends Object implements Serializable
- serialVersionUID:
- 7711754687567545052L
-
Serialized Fields
-
handle
StreamStateHandle handle
-
localPath
String localPath
-
-
Class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle extends AbstractIncrementalStateHandle implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
directoryStateHandle
DirectoryStateHandle directoryStateHandle
-
-
Class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle extends AbstractIncrementalStateHandle implements Serializable
- serialVersionUID:
- -8328808513197388231L
-
Serialized Fields
-
persistedSizeOfThisCheckpoint
long persistedSizeOfThisCheckpoint
-
privateState
List<IncrementalKeyedStateHandle.HandleAndLocalPath> privateState
Private state in the incremental checkpoint.
-
-
Class org.apache.flink.runtime.state.InputChannelStateHandle extends AbstractChannelStateHandle<InputChannelInfo> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.JavaSerializer extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<T extends Serializable> implements Serializable
- serialVersionUID:
- 5067491650263321234L
-
Class org.apache.flink.runtime.state.KeyGroupRange extends Object implements Serializable
- serialVersionUID:
- 4869121477592070607L
-
Serialized Fields
-
endKeyGroup
int endKeyGroup
-
startKeyGroup
int startKeyGroup
-
-
Class org.apache.flink.runtime.state.KeyGroupRangeOffsets extends Object implements Serializable
- serialVersionUID:
- 6595415219136429696L
-
Serialized Fields
-
keyGroupRange
KeyGroupRange keyGroupRange
the range of key-groups -
offsets
long[] offsets
the aligned array of offsets for the key-groups
-
-
Class org.apache.flink.runtime.state.KeyGroupsSavepointStateHandle extends KeyGroupsStateHandle implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.KeyGroupsStateHandle extends Object implements Serializable
- serialVersionUID:
- -8070326169926626355L
-
Serialized Fields
-
groupRangeOffsets
KeyGroupRangeOffsets groupRangeOffsets
Range of key-groups with their respective offsets in the stream state -
stateHandle
StreamStateHandle stateHandle
Inner stream handle to the actual states of the key-groups in the range -
stateHandleId
StateHandleID stateHandleId
-
-
Class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allocationBaseDirs
File[] allocationBaseDirs
All available root directories that this can potentially deliver. -
jobID
org.apache.flink.api.common.JobID jobID
JobID of the owning job. -
jobVertexID
JobVertexID jobVertexID
JobVertexID of the owning task. -
subtaskIndex
int subtaskIndex
Index of the owning subtask.
-
-
Class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo extends Object implements Serializable
- serialVersionUID:
- 3593817615858941166L
-
Serialized Fields
-
distributionMode
OperatorStateHandle.Mode distributionMode
-
offsets
long[] offsets
-
-
Class org.apache.flink.runtime.state.OperatorStreamStateHandle extends Object implements Serializable
- serialVersionUID:
- 35876522969227335L
-
Serialized Fields
-
delegateStateHandle
StreamStateHandle delegateStateHandle
-
stateNameToPartitionOffsets
Map<String,OperatorStateHandle.StateMetaInfo> stateNameToPartitionOffsets
unique state name -> offsets for available partitions in the handle stream
-
-
Class org.apache.flink.runtime.state.PhysicalStateHandleID extends org.apache.flink.util.StringBasedID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.PlaceholderStreamStateHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
fileMerged
boolean fileMerged
-
physicalID
PhysicalStateHandleID physicalID
-
stateSize
long stateSize
-
-
Class org.apache.flink.runtime.state.ResultSubpartitionStateHandle extends AbstractChannelStateHandle<ResultSubpartitionInfo> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.RetrievableStreamStateHandle extends Object implements Serializable
- serialVersionUID:
- 314567453677355L
-
Serialized Fields
-
wrappedStreamStateHandle
StreamStateHandle wrappedStreamStateHandle
wrapped inner stream state handle from which we deserialize on retrieval
-
-
Class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
stateHandleID
StateHandleID stateHandleID
-
-
Class org.apache.flink.runtime.state.SharedStateRegistryKey extends org.apache.flink.util.StringBasedID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator extends StreamCompressionDecorator implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.SnapshotResult extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jobManagerOwnedSnapshot
T extends StateObject jobManagerOwnedSnapshot
This is the state snapshot that will be reported to the Job Manager to acknowledge a checkpoint. -
taskLocalSnapshot
T extends StateObject taskLocalSnapshot
This is the state snapshot that will be reported to the Job Manager to acknowledge a checkpoint.
-
-
Class org.apache.flink.runtime.state.StateHandleID extends org.apache.flink.util.StringBasedID implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.StreamCompressionDecorator extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator extends StreamCompressionDecorator implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.VoidNamespaceSerializer extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<VoidNamespace> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.VoidNamespaceTypeInfo extends org.apache.flink.api.common.typeinfo.TypeInformation<VoidNamespace> implements Serializable
- serialVersionUID:
- 5453679706408610586L
-
-
Package org.apache.flink.runtime.state.changelog
-
Class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
checkpointId
long checkpointId
-
keyGroupRange
KeyGroupRange keyGroupRange
-
materializationID
long materializationID
-
materialized
List<KeyedStateHandle> materialized
-
nonMaterialized
List<ChangelogStateHandle> nonMaterialized
-
persistedSizeOfThisCheckpoint
long persistedSizeOfThisCheckpoint
-
stateHandleID
StateHandleID stateHandleID
-
-
Class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
localMaterialized
List<KeyedStateHandle> localMaterialized
-
localNonMaterialized
List<ChangelogStateHandle> localNonMaterialized
-
remoteHandle
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl remoteHandle
-
-
Class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl extends Object implements Serializable
- serialVersionUID:
- -8070326169926626355L
-
Serialized Fields
-
handlesAndOffsets
List<org.apache.flink.api.java.tuple.Tuple2<StreamStateHandle,Long>> handlesAndOffsets
NOTE: order is important as it reflects the order of changes. -
incrementalSize
long incrementalSize
-
keyGroupRange
KeyGroupRange keyGroupRange
-
size
long size
-
stateHandleID
StateHandleID stateHandleID
-
storageIdentifier
String storageIdentifier
-
-
Class org.apache.flink.runtime.state.changelog.SequenceNumber.GenericSequenceNumber extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
number
long number
-
-
Class org.apache.flink.runtime.state.changelog.StateChange extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
change
byte[] change
-
keyGroup
int keyGroup
-
-
-
Package org.apache.flink.runtime.state.changelog.inmemory
-
Class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
changes
List<StateChange> changes
-
from
SequenceNumber from
-
keyGroupRange
KeyGroupRange keyGroupRange
-
stateHandleID
StateHandleID stateHandleID
-
to
SequenceNumber to
-
-
-
Package org.apache.flink.runtime.state.delegate
-
Package org.apache.flink.runtime.state.filemerging
-
Class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
directory
org.apache.flink.core.fs.Path directory
-
-
Class org.apache.flink.runtime.state.filemerging.EmptyFileMergingOperatorStreamStateHandle extends FileMergingOperatorStreamStateHandle implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.filemerging.EmptySegmentFileStateHandle extends SegmentFileStateHandle implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle extends OperatorStreamStateHandle implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
sharedDirHandle
DirectoryStreamStateHandle sharedDirHandle
The directory handle of file merging under 'shared/', one for each subtask. -
taskOwnedDirHandle
DirectoryStreamStateHandle taskOwnedDirHandle
The directory handle of file merging under 'taskowed/', one for each job.
-
-
Class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
filePath
org.apache.flink.core.fs.Path filePath
The path to the file in the filesystem, fully describing the file system. -
logicalFileId
LogicalFile.LogicalFileId logicalFileId
The id for corresponding logical file. Used to retrieve LogicalFile in TM. -
scope
CheckpointedStateScope scope
The scope of the state. -
startPos
long startPos
The starting position of the segment in the file. -
stateSize
long stateSize
The size of the state in the file.
-
-
-
Package org.apache.flink.runtime.state.filesystem
-
Class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend extends AbstractStateBackend implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
baseCheckpointPath
org.apache.flink.core.fs.Path baseCheckpointPath
Deprecated.The path where checkpoints will be stored, or null, if none has been configured. -
baseSavepointPath
org.apache.flink.core.fs.Path baseSavepointPath
Deprecated.The path where savepoints will be stored, or null, if none has been configured.
-
-
Class org.apache.flink.runtime.state.filesystem.FileStateHandle extends Object implements Serializable
- serialVersionUID:
- 350284443258002355L
-
Serialized Fields
-
filePath
org.apache.flink.core.fs.Path filePath
The path to the file in the filesystem, fully describing the file system. -
stateSize
long stateSize
The size of the state in the file.
-
-
Class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
exclusiveCheckpointDir
org.apache.flink.core.fs.Path exclusiveCheckpointDir
-
externalPointer
String externalPointer
-
metadataFileHandle
FileStateHandle metadataFileHandle
-
-
Class org.apache.flink.runtime.state.filesystem.RelativeFileStateHandle extends FileStateHandle implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
relativePath
String relativePath
-
-
-
Package org.apache.flink.runtime.state.hashmap
-
Class org.apache.flink.runtime.state.hashmap.HashMapStateBackend extends AbstractStateBackend implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.runtime.state.memory
-
Class org.apache.flink.runtime.state.memory.ByteStreamStateHandle extends Object implements Serializable
- serialVersionUID:
- -5280226231202517594L
-
Serialized Fields
-
data
byte[] data
The state data. -
handleName
String handleName
A unique name of by which this state handle is identified and compared. Like a filename, allByteStreamStateHandle
with the exact same name must also have the exact same content in data.
-
-
-
Package org.apache.flink.runtime.state.metrics
-
Class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
enabled
boolean enabled
-
historySize
int historySize
-
metricGroup
org.apache.flink.metrics.MetricGroup metricGroup
-
sampleInterval
int sampleInterval
-
stateNameAsVariable
boolean stateNameAsVariable
-
-
-
Package org.apache.flink.runtime.state.storage
-
Class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage extends Object implements Serializable
- serialVersionUID:
- -8191916350224044011L
-
Serialized Fields
-
createCheckpointSubDirs
org.apache.flink.util.TernaryBoolean createCheckpointSubDirs
Switch to create checkpoint sub-directory with name of jobId. A value of 'undefined' means not yet configured, in which case the default will be used. -
fileStateThreshold
int fileStateThreshold
State below this size will be stored as part of the metadata, rather than in files. A value of '-1' means not yet configured, in which case the default will be used. -
location
org.apache.flink.runtime.state.storage.ExternalizedSnapshotLocation location
The location where snapshots will be externalized. -
writeBufferSize
int writeBufferSize
The write buffer size for created checkpoint stream, this should not be less than file state threshold when we want state below that threshold stored as part of metadata not files. A value of '-1' means not yet configured, in which case the default will be used.
-
-
Class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage extends Object implements Serializable
- serialVersionUID:
- 4109305377809414635L
-
Serialized Fields
-
createCheckpointSubDirs
org.apache.flink.util.TernaryBoolean createCheckpointSubDirs
Switch to create checkpoint sub-directory with name of jobId. A value of 'undefined' means not yet configured, in which case the default will be used. -
location
org.apache.flink.runtime.state.storage.ExternalizedSnapshotLocation location
The optional locations where snapshots will be externalized. -
maxStateSize
int maxStateSize
The maximal size that the snapshotted memory state may have.
-
-
-
Package org.apache.flink.runtime.state.ttl
-
Class org.apache.flink.runtime.state.ttl.TtlAwareSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<T> implements Serializable
-
Serialized Fields
-
isTtlEnabled
boolean isTtlEnabled
-
typeSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<T> typeSerializer
-
-
-
Class org.apache.flink.runtime.state.ttl.TtlReduceFunction extends AbstractTtlDecorator<org.apache.flink.api.common.functions.ReduceFunction<T>> implements Serializable
-
Class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer extends org.apache.flink.api.common.typeutils.CompositeSerializer<TtlValue<T>> implements Serializable
- serialVersionUID:
- 131020282727167064L
-
Class org.apache.flink.runtime.state.ttl.TtlValue extends Object implements Serializable
- serialVersionUID:
- 5221129704201125020L
-
Serialized Fields
-
lastAccessTimestamp
long lastAccessTimestamp
-
userValue
T userValue
-
-
-
Package org.apache.flink.runtime.state.v2.ttl
-
Class org.apache.flink.runtime.state.v2.ttl.TtlAggregateFunction extends AbstractTtlDecorator<org.apache.flink.api.common.functions.AggregateFunction<IN,ACC,OUT>> implements Serializable
-
Class org.apache.flink.runtime.state.v2.ttl.TtlStateFactory.TtlSerializer extends org.apache.flink.api.common.typeutils.CompositeSerializer<TtlValue<T>> implements Serializable
- serialVersionUID:
- 131020282727167064L
-
-
Package org.apache.flink.runtime.taskexecutor
-
Class org.apache.flink.runtime.taskexecutor.AccumulatorReport extends Object implements Serializable
-
Serialized Fields
-
accumulatorSnapshots
Collection<AccumulatorSnapshot> accumulatorSnapshots
-
-
-
Class org.apache.flink.runtime.taskexecutor.ExecutionDeploymentReport extends Object implements Serializable
- serialVersionUID:
- -2731996813330298044L
-
Serialized Fields
-
executions
Set<ExecutionAttemptID> executions
-
-
Class org.apache.flink.runtime.taskexecutor.SlotReport extends Object implements Serializable
- serialVersionUID:
- -3150175198722481689L
-
Serialized Fields
-
slotsStatus
Collection<SlotStatus> slotsStatus
The slots status of the TaskManager.
-
-
Class org.apache.flink.runtime.taskexecutor.SlotStatus extends Object implements Serializable
- serialVersionUID:
- 5099191707339664493L
-
Serialized Fields
-
allocationID
AllocationID allocationID
If the slot is allocated, allocationId identify its allocation; else, allocationId is null. -
jobID
org.apache.flink.api.common.JobID jobID
If the slot is allocated, jobId identify which job this slot is allocated to; else, jobId is null. -
resourceProfile
ResourceProfile resourceProfile
The resource profile of the slot. -
slotID
SlotID slotID
SlotID to identify a slot.
-
-
Class org.apache.flink.runtime.taskexecutor.TaskExecutorHeartbeatPayload extends Object implements Serializable
- serialVersionUID:
- -4556838854992435612L
-
Serialized Fields
-
clusterPartitionReport
ClusterPartitionReport clusterPartitionReport
-
slotReport
SlotReport slotReport
-
-
Class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration extends Object implements Serializable
-
Serialized Fields
-
frameworkHeap
Long frameworkHeap
-
frameworkOffHeap
Long frameworkOffHeap
-
jvmMetaspace
Long jvmMetaspace
-
jvmOverhead
Long jvmOverhead
-
managedMemoryTotal
Long managedMemoryTotal
-
networkMemory
Long networkMemory
-
taskHeap
Long taskHeap
-
taskOffHeap
Long taskOffHeap
-
totalFlinkMemory
Long totalFlinkMemory
-
totalProcessMemory
Long totalProcessMemory
-
-
-
Class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationRejection extends RegistrationResponse.Rejection implements Serializable
- serialVersionUID:
- -7447810107639038319L
-
Serialized Fields
-
reason
String reason
-
-
Class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess extends RegistrationResponse.Success implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
clusterInformation
ClusterInformation clusterInformation
-
initialTokens
byte[] initialTokens
-
registrationId
InstanceID registrationId
-
resourceManagerResourceId
ResourceID resourceManagerResourceId
-
-
Class org.apache.flink.runtime.taskexecutor.TaskExecutorToJobManagerHeartbeatPayload extends Object implements Serializable
- serialVersionUID:
- 525146950563585444L
-
Serialized Fields
-
accumulatorReport
AccumulatorReport accumulatorReport
-
executionDeploymentReport
ExecutionDeploymentReport executionDeploymentReport
-
-
-
Package org.apache.flink.runtime.taskexecutor.exceptions
-
Class org.apache.flink.runtime.taskexecutor.exceptions.PartitionUpdateException extends TaskManagerException implements Serializable
- serialVersionUID:
- 6248696963418276618L
-
Class org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException extends TaskManagerException implements Serializable
- serialVersionUID:
- -6377818046575001931L
-
Class org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException extends TaskManagerException implements Serializable
- serialVersionUID:
- -4764932098204266773L
-
Class org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException extends SlotAllocationException implements Serializable
- serialVersionUID:
- -3986333914244338888L
-
Serialized Fields
-
allocationId
AllocationID allocationId
-
jobId
org.apache.flink.api.common.JobID jobId
-
-
Class org.apache.flink.runtime.taskexecutor.exceptions.TaskException extends TaskManagerException implements Serializable
- serialVersionUID:
- 968001398103156856L
-
Class org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException extends Exception implements Serializable
- serialVersionUID:
- -2997745772227694731L
-
Class org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException extends TaskManagerException implements Serializable
- serialVersionUID:
- 4589813591317690486L
-
-
Package org.apache.flink.runtime.taskexecutor.partition
-
Class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport extends Object implements Serializable
- serialVersionUID:
- -3150175198722481689L
-
Serialized Fields
-
entries
Collection<ClusterPartitionReport.ClusterPartitionReportEntry> entries
-
-
Class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry extends Object implements Serializable
- serialVersionUID:
- -666517548300250601L
-
Serialized Fields
-
dataSetId
IntermediateDataSetID dataSetId
-
numTotalPartitions
int numTotalPartitions
-
shuffleDescriptors
Map<ResultPartitionID,ShuffleDescriptor> shuffleDescriptors
-
-
-
Package org.apache.flink.runtime.taskexecutor.slot
-
Class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allocationId
AllocationID allocationId
-
jobId
org.apache.flink.api.common.JobID jobId
-
jobTargetAddress
String jobTargetAddress
-
resourceProfile
ResourceProfile resourceProfile
-
slotID
SlotID slotID
-
-
Class org.apache.flink.runtime.taskexecutor.slot.SlotNotActiveException extends Exception implements Serializable
- serialVersionUID:
- 4305837511564584L
-
Class org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException extends Exception implements Serializable
- serialVersionUID:
- -883614807750137925L
-
Class org.apache.flink.runtime.taskexecutor.slot.SlotOffer extends Object implements Serializable
- serialVersionUID:
- -7067814231108250971L
-
Serialized Fields
-
allocationId
AllocationID allocationId
Allocation id of this slot, this would be the only identifier for this slot offer -
resourceProfile
ResourceProfile resourceProfile
The resource profile of the offered slot -
slotIndex
int slotIndex
Index of the offered slot
-
-
-
Package org.apache.flink.runtime.taskmanager
-
Class org.apache.flink.runtime.taskmanager.AsynchronousException extends Exception implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.runtime.taskmanager.TaskExecutionState extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
accumulators
AccumulatorSnapshot accumulators
Serialized user-defined accumulators -
executionId
ExecutionAttemptID executionId
-
executionState
ExecutionState executionState
-
ioMetrics
IOMetrics ioMetrics
-
throwable
org.apache.flink.util.SerializedThrowable throwable
-
-
Class org.apache.flink.runtime.taskmanager.TaskManagerLocation extends Object implements Serializable
- serialVersionUID:
- -8254407801276350716L
-
Serialized Fields
-
dataPort
int dataPort
The port that the TaskManager receive data transport connection requests at. -
hostNameSupplier
TaskManagerLocation.HostNameSupplier hostNameSupplier
The supplier for fully qualified host name and pure hostname. -
inetAddress
InetAddress inetAddress
The network address that the TaskManager binds its sockets to. -
nodeId
String nodeId
ID of the node where the TaskManager is located on. In Yarn and Native Kubernetes mode, this value will be set by resource manager when launch this TaskManager(via the config optionTaskManagerOptionsInternal.TASK_MANAGER_NODE_ID
). In other modes, this value will be the external address of the TaskManager. -
resourceID
ResourceID resourceID
The ID of the resource in which the TaskManager is started. This can be for example the YARN container ID or any other unique identifier. -
stringRepresentation
String stringRepresentation
The toString representation, eagerly constructed and cached to avoid repeated string building.
-
-
Class org.apache.flink.runtime.taskmanager.TaskManagerLocation.DefaultHostNameSupplier extends Object implements Serializable
-
Serialized Fields
-
fqdnHostName
String fqdnHostName
-
hostName
String hostName
-
inetAddress
InetAddress inetAddress
-
-
-
Class org.apache.flink.runtime.taskmanager.TaskManagerLocation.IpOnlyHostNameSupplier extends Object implements Serializable
-
Serialized Fields
-
inetAddress
InetAddress inetAddress
-
-
-
Class org.apache.flink.runtime.taskmanager.UnresolvedTaskManagerLocation extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
dataPort
int dataPort
-
externalAddress
String externalAddress
-
nodeId
String nodeId
-
resourceID
ResourceID resourceID
-
-
-
Package org.apache.flink.runtime.topology
-
Package org.apache.flink.runtime.util
-
Class org.apache.flink.runtime.util.BoundedFIFOQueue extends Object implements Serializable
- serialVersionUID:
- -890727339944580409L
-
-
Package org.apache.flink.runtime.util.config.memory
-
Class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
flinkMemory
FM extends FlinkMemory flinkMemory
-
jvmMetaspaceAndOverhead
JvmMetaspaceAndOverhead jvmMetaspaceAndOverhead
-
-
Class org.apache.flink.runtime.util.config.memory.JvmMetaspaceAndOverhead extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
metaspace
org.apache.flink.configuration.MemorySize metaspace
-
overhead
org.apache.flink.configuration.MemorySize overhead
-
-
-
Package org.apache.flink.runtime.util.config.memory.jobmanager
-
Class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemory extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
jvmHeap
org.apache.flink.configuration.MemorySize jvmHeap
-
offHeapMemory
org.apache.flink.configuration.MemorySize offHeapMemory
-
-
-
Package org.apache.flink.runtime.util.config.memory.taskmanager
-
Class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
frameworkHeap
org.apache.flink.configuration.MemorySize frameworkHeap
-
frameworkOffHeap
org.apache.flink.configuration.MemorySize frameworkOffHeap
-
managed
org.apache.flink.configuration.MemorySize managed
-
network
org.apache.flink.configuration.MemorySize network
-
taskHeap
org.apache.flink.configuration.MemorySize taskHeap
-
taskOffHeap
org.apache.flink.configuration.MemorySize taskOffHeap
-
-
-
Package org.apache.flink.runtime.webmonitor.threadinfo
-
Class org.apache.flink.runtime.webmonitor.threadinfo.ThreadInfoSamplesRequest extends Object implements Serializable
- serialVersionUID:
- -4360206136386773663L
-
Serialized Fields
-
delayBetweenSamples
Duration delayBetweenSamples
-
maxStackTraceDepth
int maxStackTraceDepth
-
numSubSamples
int numSubSamples
-
requestId
int requestId
-
-
-
Package org.apache.flink.streaming.api.checkpoint
-
Package org.apache.flink.streaming.api.connector.sink2
-
Class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo extends org.apache.flink.api.common.typeinfo.TypeInformation<CommittableMessage<CommT>> implements Serializable
-
Serialized Fields
-
committableSerializerFactory
org.apache.flink.util.function.SerializableSupplier<org.apache.flink.core.io.SimpleVersionedSerializer<CommT>> committableSerializerFactory
-
-
-
-
Package org.apache.flink.streaming.api.datastream
-
Class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.flink.util.TaggedUnion<T1,T2>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.datastream.UnsupportedTimeCharacteristicException extends org.apache.flink.util.FlinkRuntimeException implements Serializable
- serialVersionUID:
- -8109094930338075819L
-
-
Package org.apache.flink.streaming.api.environment
-
Class org.apache.flink.streaming.api.environment.CheckpointConfig extends Object implements Serializable
- serialVersionUID:
- -750378776078908147L
-
Serialized Fields
-
configuration
org.apache.flink.configuration.Configuration configuration
In the long run, this field should be somehow merged with theConfiguration
fromStreamExecutionEnvironment
.
-
-
-
Package org.apache.flink.streaming.api.functions
-
Class org.apache.flink.streaming.api.functions.KeyedProcessFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.ProcessFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.streaming.api.functions.aggregation
-
Class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator extends AggregationFunction<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
byAggregate
boolean byAggregate
-
comparator
Comparator comparator
-
fieldAccessor
FieldAccessor<T,Object> fieldAccessor
-
first
boolean first
-
-
Class org.apache.flink.streaming.api.functions.aggregation.Comparator extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.aggregation.SumAggregator extends AggregationFunction<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
adder
SumFunction adder
-
fieldAccessor
FieldAccessor<T,Object> fieldAccessor
-
isTuple
boolean isTuple
-
serializer
org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer
-
-
Class org.apache.flink.streaming.api.functions.aggregation.SumFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.streaming.api.functions.co
-
Class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- -131631008887478610L
-
Class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction extends BaseBroadcastProcessFunction implements Serializable
- serialVersionUID:
- 8352559162119034453L
-
Class org.apache.flink.streaming.api.functions.co.CoProcessFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction extends BaseBroadcastProcessFunction implements Serializable
- serialVersionUID:
- -2584726797564976453L
-
Class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- -2444626938039012398L
-
-
Package org.apache.flink.streaming.api.functions.query
-
Class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator extends org.apache.flink.streaming.api.functions.query.AbstractQueryableStateOperator<org.apache.flink.api.common.state.AppendingState<IN,?>,IN> implements Serializable
-
Class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator extends org.apache.flink.streaming.api.functions.query.AbstractQueryableStateOperator<org.apache.flink.api.common.state.ValueState<IN>,IN> implements Serializable
-
-
Package org.apache.flink.streaming.api.functions.sink.legacy
-
Class org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction extends RichSinkFunction<IN> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cleanupCalled
boolean cleanupCalled
Deprecated. -
format
org.apache.flink.api.common.io.OutputFormat<IN> format
Deprecated.
-
-
Class org.apache.flink.streaming.api.functions.sink.legacy.PrintSinkFunction extends RichSinkFunction<IN> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
writer
org.apache.flink.api.common.functions.util.PrintSinkOutputWriter<IN> writer
Deprecated.
-
-
Class org.apache.flink.streaming.api.functions.sink.legacy.RichSinkFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink extends RichSinkFunction<IN> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
autoFlush
boolean autoFlush
Deprecated. -
hostName
String hostName
Deprecated. -
isRunning
boolean isRunning
Deprecated. -
lock
org.apache.flink.util.SerializableObject lock
Deprecated. -
maxNumRetries
int maxNumRetries
Deprecated. -
port
int port
Deprecated. -
retries
int retries
Deprecated. -
schema
org.apache.flink.api.common.serialization.SerializationSchema<IN> schema
Deprecated.
-
-
-
Package org.apache.flink.streaming.api.functions.source
-
Class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator extends AbstractStreamOperator<OUT> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
serializer
org.apache.flink.api.common.typeutils.TypeSerializer<OUT> serializer
-
-
Class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory extends AbstractStreamOperatorFactory<OUT> implements Serializable
-
Serialized Fields
-
executionConfig
org.apache.flink.api.common.ExecutionConfig executionConfig
-
inputFormat
org.apache.flink.api.common.io.InputFormat<OUT,? super T extends TimestampedInputSplit> inputFormat
-
type
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> type
-
-
-
Class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit extends org.apache.flink.core.fs.FileInputSplit implements Serializable
- serialVersionUID:
- -8153252402661556005L
-
Serialized Fields
-
modificationTime
long modificationTime
The modification time of the file this split belongs to. -
splitState
Serializable splitState
The state of the split. This information is used when restoring from a checkpoint and allows to resume reading the underlying file from the point we left off.
-
-
-
Package org.apache.flink.streaming.api.functions.source.legacy
-
Class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction extends RichSourceFunction<TimestampedFileInputSplit> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
format
org.apache.flink.api.common.io.FileInputFormat<OUT> format
Deprecated.TheFileInputFormat
to be read. -
globalModificationTime
long globalModificationTime
Deprecated.The maximum file modification time seen so far. -
interval
long interval
Deprecated.The interval between consecutive path scans. -
isRunning
boolean isRunning
Deprecated. -
path
String path
Deprecated.The path to monitor. -
readerParallelism
int readerParallelism
Deprecated.The parallelism of the downstream readers. -
watchType
FileProcessingMode watchType
Deprecated.Which new data to process (seeFileProcessingMode
.
-
-
Class org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
Class org.apache.flink.streaming.api.functions.source.legacy.FileReadFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
elementsSerialized
byte[] elementsSerialized
Deprecated.The actual data elements, in serialized form. -
isRunning
boolean isRunning
Deprecated.Flag to make the source cancelable. -
numElements
int numElements
Deprecated.The number of serialized elements. -
numElementsEmitted
int numElementsEmitted
Deprecated.The number of elements emitted already. -
numElementsToSkip
int numElementsToSkip
Deprecated.The number of elements to skip initially. -
serializer
org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer
Deprecated.The (de)serializer to be used for the data elements.
-
-
Class org.apache.flink.streaming.api.functions.source.legacy.FromIteratorFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.source.legacy.FromSplittableIteratorFunction extends RichParallelSourceFunction<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
fullIterator
org.apache.flink.util.SplittableIterator<T> fullIterator
Deprecated. -
isRunning
boolean isRunning
Deprecated.
-
-
Class org.apache.flink.streaming.api.functions.source.legacy.InputFormatSourceFunction extends RichParallelSourceFunction<OUT> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.source.legacy.RichParallelSourceFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.source.legacy.RichSourceFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.source.legacy.SocketTextStreamFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.source.legacy.StatefulSequenceSource extends RichParallelSourceFunction<Long> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
end
long end
Deprecated. -
isRunning
boolean isRunning
Deprecated. -
start
long start
Deprecated.
-
-
-
Package org.apache.flink.streaming.api.functions.windowing
-
Class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<AllWindowFunction<V,R,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<WindowFunction<V,R,K,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext extends ProcessWindowFunction.Context implements Serializable
-
Serialized Fields
-
context
ProcessWindowFunction.Context context
-
window
W extends Window window
-
-
-
Class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context extends Object implements Serializable
-
Class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<AllWindowFunction<T,R,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
reduceFunction
org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction
-
-
Class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction extends ProcessAllWindowFunction<T,R,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction extends ProcessWindowFunction<T,R,K,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<WindowFunction<T,R,K,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
reduceFunction
org.apache.flink.api.common.functions.ReduceFunction<T> reduceFunction
-
-
-
Package org.apache.flink.streaming.api.graph
-
Class org.apache.flink.streaming.api.graph.NonChainedOutput extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
bufferTimeout
long bufferTimeout
Buffer flush timeout of this output. -
consumerMaxParallelism
int consumerMaxParallelism
Max parallelism of the consumer vertex. -
consumerParallelism
int consumerParallelism
Parallelism of the consumer vertex. -
dataSetId
IntermediateDataSetID dataSetId
ID of the produced intermediate dataset. -
isPersistentDataSet
boolean isPersistentDataSet
Whether this intermediate dataset is a persistent dataset or not. -
outputTag
org.apache.flink.util.OutputTag<?> outputTag
The side-output tag (if any). -
partitioner
StreamPartitioner<?> partitioner
The corresponding data partitioner. -
partitionType
ResultPartitionType partitionType
TargetResultPartitionType
. -
sourceNodeId
int sourceNodeId
ID of the producerStreamNode
. -
supportsUnalignedCheckpoints
boolean supportsUnalignedCheckpoints
Is unaligned checkpoint supported.
-
-
Class org.apache.flink.streaming.api.graph.StreamConfig extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
config
org.apache.flink.configuration.Configuration config
-
deserializedWatermarkDeclarations
Set<AbstractInternalWatermarkDeclaration<?>> deserializedWatermarkDeclarations
To reduce the deserialization overhead of reading the WatermarkDeclaration, we'll store the result after the first deserialization, and return it directly in subsequent reading requests. -
removedKeys
Set<String> removedKeys
In order to release memory during processing data, some keys are removed inStreamConfig.clearInitialConfigs()
. Recording these keys here to prevent they are accessed after removing.
-
-
Class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig extends Object implements Serializable
-
Serialized Fields
-
inputGateIndex
int inputGateIndex
-
inputRequirement
StreamConfig.InputRequirement inputRequirement
-
typeSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<?> typeSerializer
-
-
-
Class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig extends Object implements Serializable
-
Serialized Fields
-
inputEdge
StreamEdge inputEdge
-
-
-
Class org.apache.flink.streaming.api.graph.StreamEdge extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
bufferTimeout
long bufferTimeout
-
edgeId
String edgeId
-
exchangeMode
StreamExchangeMode exchangeMode
-
interInputsKeysCorrelated
boolean interInputsKeysCorrelated
There are relationships between multiple inputs, if the data corresponding to a specific join key from one input is split, the corresponding join key data from the other inputs must be duplicated (meaning that it must be sent to the downstream nodes where the split data is sent). -
intermediateDatasetIdToProduce
IntermediateDataSetID intermediateDatasetIdToProduce
-
intraInputKeyCorrelated
boolean intraInputKeyCorrelated
For this edge the data corresponding to a specific join key must be sent to the same downstream subtask. -
outputPartitioner
StreamPartitioner<?> outputPartitioner
TheStreamPartitioner
on thisStreamEdge
. -
outputTag
org.apache.flink.util.OutputTag outputTag
The side-output tag (if any) of thisStreamEdge
. -
sourceId
int sourceId
-
sourceOperatorName
String sourceOperatorName
The name of the operator in the source vertex. -
supportsUnalignedCheckpoints
boolean supportsUnalignedCheckpoints
-
targetId
int targetId
-
targetOperatorName
String targetOperatorName
The name of the operator in the target vertex. -
typeNumber
int typeNumber
The type number of the input for co-tasks. -
uniqueId
int uniqueId
Note that this field doesn't have to be unique among allStreamEdge
s. It's enough if this field ensures that all logical instances ofStreamEdge
are unique, andStreamEdge.hashCode()
are different andStreamEdge.equals(Object)
returns false, for every possible pair ofStreamEdge
. Especially among two differentStreamEdge
s that are connecting the same pair of nodes.
-
-
Class org.apache.flink.streaming.api.graph.StreamGraph extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allVerticesInSameSlotSharingGroupByDefault
boolean allVerticesInSameSlotSharingGroupByDefault
Flag to indicate whether to put all vertices into the same slot sharing group by default. -
autoParallelismEnabled
boolean autoParallelismEnabled
-
checkpointConfig
CheckpointConfig checkpointConfig
-
checkpointingSettings
JobCheckpointingSettings checkpointingSettings
-
classpath
List<URL> classpath
List of classpath required to run this job. -
descriptionMode
org.apache.flink.configuration.PipelineOptions.VertexDescriptionMode descriptionMode
-
dynamic
boolean dynamic
-
enableCheckpointsAfterTasksFinish
boolean enableCheckpointsAfterTasksFinish
-
globalExchangeMode
GlobalStreamExchangeMode globalExchangeMode
-
initialClientHeartbeatTimeout
long initialClientHeartbeatTimeout
-
isEmpty
boolean isEmpty
-
jobConfiguration
org.apache.flink.configuration.Configuration jobConfiguration
-
jobId
org.apache.flink.api.common.JobID jobId
-
jobName
String jobName
-
jobStatusHooks
List<org.apache.flink.core.execution.JobStatusHook> jobStatusHooks
-
jobType
JobType jobType
-
nodeToHeadOperatorCache
Map<StreamNode,StreamOperatorFactory<?>> nodeToHeadOperatorCache
-
savepointRestoreSettings
SavepointRestoreSettings savepointRestoreSettings
-
serializedWatermarkDeclarations
byte[] serializedWatermarkDeclarations
-
sinks
Set<Integer> sinks
-
slotSharingGroupResources
Map<String,ResourceProfile> slotSharingGroupResources
-
sources
Set<Integer> sources
-
streamNodeMinResources
Map<Integer,org.apache.flink.api.common.operators.ResourceSpec> streamNodeMinResources
-
timerServiceProvider
InternalTimeServiceManager.Provider timerServiceProvider
-
userArtifacts
Map<String,org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry> userArtifacts
Set of custom files required to run this job. -
userDefinedObjectsHolder
org.apache.flink.streaming.api.graph.StreamGraph.UserDefinedObjectsHolder userDefinedObjectsHolder
-
userJarBlobKeys
List<PermanentBlobKey> userJarBlobKeys
Set of blob keys identifying the JAR files required to run this job. -
userJars
List<org.apache.flink.core.fs.Path> userJars
Set of JAR files required to run this job. -
vertexIDtoBrokerID
Map<Integer,String> vertexIDtoBrokerID
-
vertexIDtoLoopTimeout
Map<Integer,Long> vertexIDtoLoopTimeout
-
vertexNameIncludeIndexPrefix
boolean vertexNameIncludeIndexPrefix
-
-
Class org.apache.flink.streaming.api.graph.StreamNode extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attribute
org.apache.flink.api.common.attribute.Attribute attribute
-
bufferTimeout
long bufferTimeout
-
coLocationGroup
String coLocationGroup
-
consumeClusterDatasetId
IntermediateDataSetID consumeClusterDatasetId
-
id
int id
-
inEdges
List<StreamEdge> inEdges
-
inputFormat
org.apache.flink.api.common.io.InputFormat<?,?> inputFormat
-
inputRequirements
Map<Integer,StreamConfig.InputRequirement> inputRequirements
-
jobVertexClass
Class<? extends TaskInvokable> jobVertexClass
-
managedMemoryOperatorScopeUseCaseWeights
Map<org.apache.flink.core.memory.ManagedMemoryUseCase,Integer> managedMemoryOperatorScopeUseCaseWeights
-
managedMemorySlotScopeUseCases
Set<org.apache.flink.core.memory.ManagedMemoryUseCase> managedMemorySlotScopeUseCases
-
maxParallelism
int maxParallelism
Maximum parallelism for this stream node. The maximum parallelism is the upper limit for dynamic scaling and the number of key groups used for partitioned state. -
minResources
org.apache.flink.api.common.operators.ResourceSpec minResources
-
operatorDescription
String operatorDescription
-
operatorName
String operatorName
-
outEdges
List<StreamEdge> outEdges
-
outputFormat
org.apache.flink.api.common.io.OutputFormat<?> outputFormat
-
parallelism
int parallelism
-
parallelismConfigured
boolean parallelismConfigured
-
preferredResources
org.apache.flink.api.common.operators.ResourceSpec preferredResources
-
slotSharingGroup
String slotSharingGroup
-
stateKeySerializer
org.apache.flink.api.common.typeutils.TypeSerializer<?> stateKeySerializer
-
statePartitioners
org.apache.flink.api.java.functions.KeySelector<?,?>[] statePartitioners
-
supportsConcurrentExecutionAttempts
boolean supportsConcurrentExecutionAttempts
-
transformationUID
String transformationUID
-
typeSerializerOut
org.apache.flink.api.common.typeutils.TypeSerializer<?> typeSerializerOut
-
typeSerializersIn
org.apache.flink.api.common.typeutils.TypeSerializer<?>[] typeSerializersIn
-
userHash
String userHash
-
-
-
Package org.apache.flink.streaming.api.operators
-
Class org.apache.flink.streaming.api.operators.AbstractStreamOperator extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory extends Object implements Serializable
-
Serialized Fields
-
chainingStrategy
ChainingStrategy chainingStrategy
-
-
-
Class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2 extends Object implements Serializable
-
Serialized Fields
-
cancelables
org.apache.flink.core.fs.CloseableRegistry cancelables
-
combinedWatermark
org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus combinedWatermark
-
config
StreamConfig config
-
executionConfig
org.apache.flink.api.common.ExecutionConfig executionConfig
-
lastRecordAttributes
RecordAttributes[] lastRecordAttributes
-
latencyStats
LatencyStats latencyStats
-
mailboxExecutor
org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor
-
metrics
InternalOperatorMetricGroup metrics
Metric group for the operator. -
output
Output<StreamRecord<OUT>> output
-
processingTimeService
ProcessingTimeService processingTimeService
-
runtimeContext
StreamingRuntimeContext runtimeContext
-
stateHandler
StreamOperatorStateHandler stateHandler
-
timeServiceManager
InternalTimeServiceManager<?> timeServiceManager
-
userCodeClassLoader
ClassLoader userCodeClassLoader
-
watermarkProcessor
MailboxWatermarkProcessor watermarkProcessor
-
-
-
Class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator extends AbstractStreamOperator<OUT> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
userFunction
F extends org.apache.flink.api.common.functions.Function userFunction
The user function.
-
-
Class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator extends AbstractUdfStreamOperator<IN,org.apache.flink.api.common.functions.ReduceFunction<IN>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
serializer
org.apache.flink.api.common.typeutils.TypeSerializer<IN> serializer
-
timerService
InternalTimerService<VoidNamespace> timerService
-
-
Class org.apache.flink.streaming.api.operators.InputSelection extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
inputMask
long inputMask
-
-
Class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<TimerHeapInternalTimer<K,N>> implements Serializable
- serialVersionUID:
- 1119562170939152304L
-
Class org.apache.flink.streaming.api.operators.KeyedProcessOperator extends AbstractUdfStreamOperator<OUT,KeyedProcessFunction<K,IN,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator extends AbstractUdfStreamOperator<OUT,ProcessFunction<IN,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.MapPartitionOperator extends AbstractUdfStreamOperator<OUT,org.apache.flink.api.common.functions.MapPartitionFunction<IN,OUT>> implements Serializable
-
Class org.apache.flink.streaming.api.operators.OperatorAttributes extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
internalSorterSupported
boolean internalSorterSupported
-
outputOnlyAfterEndOfStream
boolean outputOnlyAfterEndOfStream
-
-
Class org.apache.flink.streaming.api.operators.PartitionAggregateOperator extends AbstractUdfStreamOperator<OUT,org.apache.flink.api.common.functions.AggregateFunction<IN,ACC,OUT>> implements Serializable
-
Class org.apache.flink.streaming.api.operators.PartitionReduceOperator extends AbstractUdfStreamOperator<IN,org.apache.flink.api.common.functions.ReduceFunction<IN>> implements Serializable
-
Class org.apache.flink.streaming.api.operators.ProcessOperator extends AbstractUdfStreamOperator<OUT,ProcessFunction<IN,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
currentWatermark
long currentWatermark
We listen to this ourselves because we don't have anInternalTimerService
.
-
-
Class org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory extends SimpleOperatorFactory<OUT> implements Serializable
-
Serialized Fields
-
operator
StreamSource<OUT,InputFormatSourceFunction<OUT>> operator
-
-
-
Class org.apache.flink.streaming.api.operators.SimpleOperatorFactory extends AbstractStreamOperatorFactory<OUT> implements Serializable
-
Serialized Fields
-
operator
StreamOperator<OUT> operator
-
-
-
Class org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory extends SimpleOperatorFactory<OUT> implements Serializable
-
Serialized Fields
-
outputFormat
org.apache.flink.api.common.io.OutputFormat<IN> outputFormat
-
-
-
Class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory extends SimpleOperatorFactory<OUT> implements Serializable
-
Serialized Fields
-
operator
AbstractUdfStreamOperator<OUT,?> operator
-
-
-
Class org.apache.flink.streaming.api.operators.SourceOperator extends AbstractStreamOperator<OUT> implements Serializable
- serialVersionUID:
- 1405537676017904695L
-
Serialized Fields
-
allowUnalignedSourceSplits
boolean allowUnalignedSourceSplits
-
availabilityHelper
org.apache.flink.streaming.api.operators.SourceOperator.SourceOperatorAvailabilityHelper availabilityHelper
-
canEmitBatchOfRecords
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords
-
configuration
org.apache.flink.configuration.Configuration configuration
The Flink configuration. -
currentlyPausedSplits
Set<String> currentlyPausedSplits
-
currentMainOutput
org.apache.flink.api.connector.source.ReaderOutput<OUT> currentMainOutput
-
currentMaxDesiredWatermark
long currentMaxDesiredWatermark
-
emitProgressiveWatermarks
boolean emitProgressiveWatermarks
Whether to emit intermediate watermarks or only one final watermark at the end of input. -
eventTimeLogic
TimestampsAndWatermarks<OUT> eventTimeLogic
The event time and watermarking logic. Ideally this would be eagerly passed into this operator, but we currently need to instantiate this lazily, because the metric groups exist only later. -
finished
CompletableFuture<Void> finished
-
idle
boolean idle
-
lastInvokedOutput
PushingAsyncDataInput.DataOutput<OUT> lastInvokedOutput
-
latencyMarkerEmitter
org.apache.flink.streaming.api.operators.LatencyMarkerEmitter<OUT> latencyMarkerEmitter
-
latestWatermark
long latestWatermark
-
localHostname
String localHostname
Host name of the machine where the operator runs, to support locality aware work assignment. -
operatingMode
org.apache.flink.streaming.api.operators.SourceOperator.OperatingMode operatingMode
A mode to control the behaviour of theSourceOperator.emitNext(DataOutput)
method. -
operatorEventGateway
OperatorEventGateway operatorEventGateway
The event gateway through which this operator talks to its coordinator. -
readerFactory
org.apache.flink.util.function.FunctionWithException<org.apache.flink.api.connector.source.SourceReaderContext,org.apache.flink.api.connector.source.SourceReader<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit>,Exception> readerFactory
The factory for the source reader. This is a workaround, because currently the SourceReader must be lazily initialized, which is mainly because the metrics groups that the reader relies on is lazily initialized. -
readerState
org.apache.flink.api.common.state.ListState<SplitT extends org.apache.flink.api.connector.source.SourceSplit> readerState
The state that holds the currently assigned splits. -
sourceMetricGroup
InternalSourceReaderMetricGroup sourceMetricGroup
-
sourceReader
org.apache.flink.api.connector.source.SourceReader<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit> sourceReader
The source reader that does most of the work. -
splitCurrentWatermarks
Map<String,Long> splitCurrentWatermarks
-
splitSerializer
org.apache.flink.core.io.SimpleVersionedSerializer<SplitT extends org.apache.flink.api.connector.source.SourceSplit> splitSerializer
The serializer for the splits, applied to the split types before storing them in the reader state. -
splitsToInitializeOutput
List<SplitT extends org.apache.flink.api.connector.source.SourceSplit> splitsToInitializeOutput
-
waitingForAlignmentFuture
CompletableFuture<Void> waitingForAlignmentFuture
Can be not completed only inSourceOperator.OperatingMode.WAITING_FOR_ALIGNMENT
mode. -
watermarkAlignmentParams
org.apache.flink.api.common.eventtime.WatermarkAlignmentParams watermarkAlignmentParams
-
watermarkIsAlignedMap
Map<String,Boolean> watermarkIsAlignedMap
Watermark identifier to whether the watermark are aligned. -
watermarkStrategy
org.apache.flink.api.common.eventtime.WatermarkStrategy<OUT> watermarkStrategy
The factory for timestamps and watermark generators.
-
-
Class org.apache.flink.streaming.api.operators.SourceOperatorFactory extends AbstractStreamOperatorFactory<OUT> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
coordinatorListeningID
String coordinatorListeningID
-
emitProgressiveWatermarks
boolean emitProgressiveWatermarks
Whether to emit intermediate watermarks or only one final watermark at the end of input. -
numCoordinatorWorkerThread
int numCoordinatorWorkerThread
The number of worker thread for the source coordinator. -
source
org.apache.flink.api.connector.source.Source<OUT,?,?> source
TheSource
to create theSourceOperator
. -
watermarkStrategy
org.apache.flink.api.common.eventtime.WatermarkStrategy<OUT> watermarkStrategy
The event time setup (timestamp assigners, watermark generators, etc.).
-
-
Class org.apache.flink.streaming.api.operators.StreamFilter extends AbstractUdfStreamOperator<IN,org.apache.flink.api.common.functions.FilterFunction<IN>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.StreamFlatMap extends AbstractUdfStreamOperator<OUT,org.apache.flink.api.common.functions.FlatMapFunction<IN,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.StreamGroupedReduceAsyncStateOperator extends AbstractAsyncStateUdfStreamOperator<IN,org.apache.flink.api.common.functions.ReduceFunction<IN>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
serializer
org.apache.flink.api.common.typeutils.TypeSerializer<IN> serializer
-
-
Class org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator extends AbstractUdfStreamOperator<IN,org.apache.flink.api.common.functions.ReduceFunction<IN>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
serializer
org.apache.flink.api.common.typeutils.TypeSerializer<IN> serializer
-
-
Class org.apache.flink.streaming.api.operators.StreamMap extends AbstractUdfStreamOperator<OUT,org.apache.flink.api.common.functions.MapFunction<IN,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.StreamProject extends AbstractStreamOperator<OUT extends org.apache.flink.api.java.tuple.Tuple> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
fields
int[] fields
-
numFields
int numFields
-
outSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<OUT extends org.apache.flink.api.java.tuple.Tuple> outSerializer
-
-
Class org.apache.flink.streaming.api.operators.StreamSink extends AbstractUdfStreamOperator<Object,SinkFunction<IN>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
currentWatermark
long currentWatermark
We listen to this ourselves because we don't have anInternalTimerService
.
-
-
Class org.apache.flink.streaming.api.operators.StreamSource extends AbstractUdfStreamOperator<OUT,SRC extends SourceFunction<OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
emitProgressiveWatermarks
boolean emitProgressiveWatermarks
Deprecated.Whether to emit intermediate watermarks or only one final watermark at the end of input.
-
-
Class org.apache.flink.streaming.api.operators.TimerSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<TimerHeapInternalTimer<K,N>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
immutableType
boolean immutableType
True iff the serialized type (and composite objects) are immutable. -
keySerializer
org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer
Serializer for the key. -
length
int length
The bytes written for one timer, or -1 if variable size. -
namespaceSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer
Serializer for the namespace.
-
-
-
Package org.apache.flink.streaming.api.operators.co
-
Class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator extends CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> implements Serializable
- serialVersionUID:
- 5926499536290284870L
-
Class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator extends CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> implements Serializable
- serialVersionUID:
- -1869740381935471752L
-
Class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator extends AbstractUdfStreamOperator<OUT,KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT>> implements Serializable
- serialVersionUID:
- 5926499536290284870L
-
Serialized Fields
-
broadcastStateDescriptors
List<org.apache.flink.api.common.state.MapStateDescriptor<?,?>> broadcastStateDescriptors
-
-
Class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator extends AbstractUdfStreamOperator<OUT,BroadcastProcessFunction<IN1,IN2,OUT>> implements Serializable
- serialVersionUID:
- -1869740381935471752L
-
Serialized Fields
-
broadcastStateDescriptors
List<org.apache.flink.api.common.state.MapStateDescriptor<?,?>> broadcastStateDescriptors
-
currentWatermark
long currentWatermark
We listen to this ourselves because we don't have anInternalTimerService
.
-
-
Class org.apache.flink.streaming.api.operators.co.CoProcessOperator extends AbstractUdfStreamOperator<OUT,CoProcessFunction<IN1,IN2,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
currentWatermark
long currentWatermark
We listen to this ourselves because we don't have anInternalTimerService
.
-
-
Class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap extends AbstractUdfStreamOperator<OUT,CoFlatMapFunction<IN1,IN2,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.co.CoStreamMap extends AbstractUdfStreamOperator<OUT,CoMapFunction<IN1,IN2,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator extends AbstractUdfStreamOperator<OUT,ProcessJoinFunction<T1,T2,OUT>> implements Serializable
- serialVersionUID:
- -5380774605111543454L
-
Serialized Fields
-
leftLateDataOutputTag
org.apache.flink.util.OutputTag<T1> leftLateDataOutputTag
-
leftTypeSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<T1> leftTypeSerializer
-
lowerBound
long lowerBound
-
rightLateDataOutputTag
org.apache.flink.util.OutputTag<T2> rightLateDataOutputTag
-
rightTypeSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<T2> rightTypeSerializer
-
upperBound
long upperBound
-
-
Class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<IntervalJoinOperator.BufferEntry<T>> implements Serializable
- serialVersionUID:
- -20197698803836236L
-
Serialized Fields
-
elementSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<T> elementSerializer
-
-
Class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator extends AbstractUdfStreamOperator<OUT,KeyedCoProcessFunction<K,IN1,IN2,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator extends AbstractUdfStreamOperator<OUT,CoProcessFunction<IN1,IN2,OUT>> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.streaming.api.operators.collect
-
Class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
offset
long offset
-
version
String version
-
-
Class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
address
InetSocketAddress address
-
-
Class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction extends RichSinkFunction<IN> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator extends StreamSink<IN> implements Serializable
-
Serialized Fields
-
sinkFunction
CollectSinkFunction<IN> sinkFunction
-
-
-
Class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider extends Object implements Serializable
-
Serialized Fields
-
operatorId
OperatorID operatorId
-
socketTimeout
int socketTimeout
-
-
-
Class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory extends SimpleUdfStreamOperatorFactory<Object> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
operator
CollectSinkOperator<IN> operator
-
socketTimeoutMillis
int socketTimeoutMillis
-
-
-
Package org.apache.flink.streaming.api.operators.legacy
-
Package org.apache.flink.streaming.api.operators.sorted.state
-
Class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage extends Object implements Serializable
-
Class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend extends Object implements Serializable
-
-
Package org.apache.flink.streaming.api.operators.sortpartition
-
Class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator extends org.apache.flink.api.common.typeutils.TypeComparator<org.apache.flink.api.java.tuple.Tuple2<byte[],INPUT>> implements Serializable
-
Class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator extends AbstractStreamOperator<INPUT> implements Serializable
-
Serialized Fields
-
dataOutputSerializer
org.apache.flink.core.memory.DataOutputSerializer dataOutputSerializer
A buffer to save the serialized record key. -
inputType
org.apache.flink.api.common.typeinfo.TypeInformation<INPUT> inputType
The type information of input records. -
positionSortField
int positionSortField
The int field to indicate the sort key for records with tuple type, which will be -1 if it's not used. -
recordKeySerializer
org.apache.flink.api.common.typeutils.TypeSerializer<KEY> recordKeySerializer
-
recordSorter
PushSorter<org.apache.flink.api.java.tuple.Tuple2<byte[],INPUT>> recordSorter
The sorter to sort both key and record if the record is not sorted byKeySelector
. -
recordSorterForSelector
PushSorter<org.apache.flink.api.java.tuple.Tuple2<byte[],org.apache.flink.api.java.tuple.Tuple2<?,INPUT>>> recordSorterForSelector
The sorter to sort both key and record if the record is sorted byKeySelector
. -
sortFieldSelector
org.apache.flink.api.java.functions.KeySelector<INPUT,?> sortFieldSelector
The selector to create the sort key for records, which will be null if it's not used. -
sortOrder
org.apache.flink.api.common.operators.Order sortOrder
The order to sort records. -
stringSortField
String stringSortField
The string field to indicate the sort key for records with tuple or pojo type, which will be null if it's not used.
-
-
-
Class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator extends AbstractStreamOperator<INPUT> implements Serializable
-
Serialized Fields
-
inputType
org.apache.flink.api.common.typeinfo.TypeInformation<INPUT> inputType
The type information of input records. -
positionSortField
int positionSortField
The int field to indicate the sort key for records with tuple type, which will be -1 if it's not used. -
recordSorter
PushSorter<INPUT> recordSorter
The sorter to sort record if the record is not sorted byKeySelector
. -
recordSorterForKeySelector
PushSorter<org.apache.flink.api.java.tuple.Tuple2<?,INPUT>> recordSorterForKeySelector
The sorter to sort record if the record is sorted byKeySelector
. -
sortFieldSelector
org.apache.flink.api.java.functions.KeySelector<INPUT,?> sortFieldSelector
The selector to create the sort key for records, which will be null if it's not used. -
sortOrder
org.apache.flink.api.common.operators.Order sortOrder
The order to sort records. -
stringSortField
String stringSortField
The string field to indicate the sort key for records with tuple or pojo type, which will be null if it's not used.
-
-
-
Class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator extends org.apache.flink.api.common.typeutils.TypeComparator<org.apache.flink.api.java.tuple.Tuple2<byte[],INPUT>> implements Serializable
-
-
Package org.apache.flink.streaming.api.windowing.assigners
-
Class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows extends WindowAssigner<Object,GlobalWindow> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
defaultTrigger
Trigger<Object,GlobalWindow> defaultTrigger
-
-
Class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.EndOfStreamTrigger extends Trigger<Object,GlobalWindow> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger extends Trigger<Object,GlobalWindow> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner extends WindowAssigner<T,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows extends WindowAssigner<Object,TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
offset
long offset
-
size
long size
-
slide
long slide
-
-
Class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows extends WindowAssigner<Object,TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
offset
long offset
-
size
long size
-
slide
long slide
-
-
Class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows extends WindowAssigner<Object,TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
globalOffset
long globalOffset
-
size
long size
-
staggerOffset
Long staggerOffset
-
windowStagger
WindowStagger windowStagger
-
-
Class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows extends WindowAssigner<Object,TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
globalOffset
long globalOffset
-
size
long size
-
staggerOffset
Long staggerOffset
-
windowStagger
WindowStagger windowStagger
-
-
Class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.streaming.api.windowing.evictors
-
Class org.apache.flink.streaming.api.windowing.evictors.CountEvictor extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
doEvictAfter
boolean doEvictAfter
-
maxCount
long maxCount
-
-
-
Package org.apache.flink.streaming.api.windowing.triggers
-
Class org.apache.flink.streaming.api.windowing.triggers.CountTrigger extends Trigger<Object,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
maxCount
long maxCount
-
stateDesc
org.apache.flink.api.common.state.ReducingStateDescriptor<Long> stateDesc
-
-
Class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger extends Trigger<Object,TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger extends Trigger<Object,TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger extends Trigger<T,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.windowing.triggers.Trigger extends Object implements Serializable
- serialVersionUID:
- -4104633972991191369L
-
-
Package org.apache.flink.streaming.api.windowing.windows
-
Class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<GlobalWindow> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<TimeWindow> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.streaming.runtime.operators
-
Class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator extends AbstractStreamOperator<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
emitProgressiveWatermarks
boolean emitProgressiveWatermarks
Whether to emit intermediate watermarks or only one final watermark at the end of input. -
watermarkStrategy
org.apache.flink.api.common.eventtime.WatermarkStrategy<T> watermarkStrategy
-
-
Class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperatorFactory extends AbstractStreamOperatorFactory<T> implements Serializable
-
Serialized Fields
-
emitProgressiveWatermarks
boolean emitProgressiveWatermarks
Whether to emit intermediate watermarks or only one final watermark at the end of input. -
watermarkStrategy
org.apache.flink.api.common.eventtime.WatermarkStrategy<T> watermarkStrategy
-
-
-
-
Package org.apache.flink.streaming.runtime.operators.sink
-
Class org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory extends AbstractStreamOperatorFactory<CommittableMessage<CommT>> implements Serializable
-
Serialized Fields
-
isBatchMode
boolean isBatchMode
-
isCheckpointingEnabled
boolean isCheckpointingEnabled
-
sink
org.apache.flink.api.connector.sink2.SupportsCommitter<CommT> sink
-
-
-
Class org.apache.flink.streaming.runtime.operators.sink.GlobalCommitterOperator extends AbstractStreamOperator<Void> implements Serializable
-
Serialized Fields
-
commitOnInput
boolean commitOnInput
Depending on whether there is an upstream committer or it's connected to a writer, we may either wait for notifyCheckpointCompleted or not. -
committableCollector
CommittableCollector<CommT> committableCollector
-
committableSerializer
org.apache.flink.core.io.SimpleVersionedSerializer<CommT> committableSerializer
-
committableSerializerFactory
org.apache.flink.util.function.SerializableSupplier<org.apache.flink.core.io.SimpleVersionedSerializer<CommT>> committableSerializerFactory
-
committer
org.apache.flink.api.connector.sink2.Committer<CommT> committer
-
committerFactory
org.apache.flink.util.function.SerializableFunction<org.apache.flink.api.connector.sink2.CommitterInitContext,org.apache.flink.api.connector.sink2.Committer<CommT>> committerFactory
-
globalCommittableSerializer
org.apache.flink.core.io.SimpleVersionedSerializer<GlobalCommT> globalCommittableSerializer
-
globalCommitterState
org.apache.flink.api.common.state.ListState<org.apache.flink.streaming.runtime.operators.sink.GlobalCommittableWrapper<CommT,GlobalCommT>> globalCommitterState
-
lastCompletedCheckpointId
long lastCompletedCheckpointId
-
maxRetries
int maxRetries
-
metricGroup
org.apache.flink.metrics.groups.SinkCommitterMetricGroup metricGroup
-
sinkV1State
List<GlobalCommT> sinkV1State
-
-
-
Class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory extends AbstractStreamOperatorFactory<CommittableMessage<CommT>> implements Serializable
-
Serialized Fields
-
sink
org.apache.flink.api.connector.sink2.Sink<InputT> sink
-
-
-
-
Package org.apache.flink.streaming.runtime.operators.util
-
Package org.apache.flink.streaming.runtime.operators.windowing
-
Class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator extends WindowOperator<K,IN,Iterable<IN>,OUT,W extends Window> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorFactory extends WindowOperatorFactory<K,IN,Iterable<IN>,OUT,W extends Window> implements Serializable
-
Class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator extends AbstractUdfStreamOperator<OUT,InternalWindowFunction<ACC,OUT,K,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allowedLateness
long allowedLateness
The allowed lateness for elements. This is used for:- Deciding if an element should be dropped from a window due to lateness.
- Clearing the state of a window if the system time passes the
window.maxTimestamp + allowedLateness
landmark.
-
keySelector
org.apache.flink.api.java.functions.KeySelector<IN,K> keySelector
-
keySerializer
org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer
For serializing the key in checkpoints. -
lateDataOutputTag
org.apache.flink.util.OutputTag<IN> lateDataOutputTag
OutputTag
to use for late arriving events. Elements for whichwindow.maxTimestamp + allowedLateness
is smaller than the current watermark will be emitted to this. -
trigger
Trigger<? super IN,? super W extends Window> trigger
-
windowAssigner
WindowAssigner<? super IN,W extends Window> windowAssigner
-
windowSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<W extends Window> windowSerializer
For serializing the window in checkpoints. -
windowStateDescriptor
org.apache.flink.api.common.state.StateDescriptor<? extends org.apache.flink.api.common.state.AppendingState<IN,ACC>,?> windowStateDescriptor
-
-
Class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext extends Object implements Serializable
-
Serialized Fields
-
window
W extends Window window
-
windowState
WindowOperator.AbstractPerWindowStateStore windowState
-
-
-
Class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory extends AbstractStreamOperatorFactory<OUT> implements Serializable
-
Serialized Fields
-
allowedLateness
long allowedLateness
-
keySelector
org.apache.flink.api.java.functions.KeySelector<IN,K> keySelector
-
keySerializer
org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer
-
lateDataOutputTag
org.apache.flink.util.OutputTag<IN> lateDataOutputTag
-
trigger
Trigger<? super IN,? super W extends Window> trigger
-
windowAssigner
WindowAssigner<? super IN,W extends Window> windowAssigner
-
windowFunction
InternalWindowFunction<ACC,OUT,K,W extends Window> windowFunction
-
windowSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<W extends Window> windowSerializer
-
windowStateDescriptor
org.apache.flink.api.common.state.StateDescriptor<? extends org.apache.flink.api.common.state.AppendingState<IN,ACC>,?> windowStateDescriptor
-
-
-
-
Package org.apache.flink.streaming.runtime.operators.windowing.functions
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessAllWindowFunction<V,R,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessWindowFunction<V,R,K,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<AllWindowFunction<IN,OUT,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessAllWindowFunction<IN,OUT,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessWindowFunction<IN,OUT,KEY,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<WindowFunction<IN,OUT,KEY,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext extends ProcessWindowFunction.Context implements Serializable
-
Serialized Fields
-
internalContext
InternalWindowFunction.InternalWindowContext internalContext
-
window
W extends Window window
-
-
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<AllWindowFunction<IN,OUT,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessAllWindowFunction<IN,OUT,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<ProcessWindowFunction<IN,OUT,KEY,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction extends org.apache.flink.api.common.functions.WrappingFunction<WindowFunction<IN,OUT,KEY,W extends Window>> implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.streaming.runtime.partitioner
-
Class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner extends StreamPartitioner<T> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper extends StreamPartitioner<T> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner extends ForwardPartitioner<T> implements Serializable
-
Serialized Fields
-
hashPartitioner
StreamPartitioner<T> hashPartitioner
-
-
-
Class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner extends ForwardPartitioner<T> implements Serializable
-
Class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner extends StreamPartitioner<T> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner extends StreamPartitioner<T> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner extends StreamPartitioner<T> implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner extends StreamPartitioner<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
nextChannelToSendTo
int nextChannelToSendTo
-
-
Class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner extends StreamPartitioner<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
nextChannelToSendTo
int nextChannelToSendTo
-
-
Class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner extends StreamPartitioner<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
random
Random random
-
-
Class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
numberOfChannels
int numberOfChannels
-
supportsUnalignedCheckpoint
boolean supportsUnalignedCheckpoint
By default, all partitioner exceptStreamPartitioner.isBroadcast()
orStreamPartitioner.isPointwise()
support unaligned checkpoints. However, transformations may disable unaligned checkpoints for specific cases.
-
-
-
Package org.apache.flink.streaming.runtime.streamrecord
-
Class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<StreamElement> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
typeSerializer
org.apache.flink.api.common.typeutils.TypeSerializer<T> typeSerializer
-
-
-
Package org.apache.flink.streaming.runtime.tasks
-
Class org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException extends org.apache.flink.util.WrappingRuntimeException implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.runtime.tasks.StreamTaskException extends RuntimeException implements Serializable
- serialVersionUID:
- 8392043527067472439L
-
Class org.apache.flink.streaming.runtime.tasks.TimerException extends AsynchronousException implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.streaming.runtime.tasks.mailbox
-
Class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.MailboxClosedException extends IllegalStateException implements Serializable
-
-
Package org.apache.flink.streaming.runtime.translators
-
Class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.IdentityStreamOperator extends AbstractStreamOperator<T> implements Serializable
- serialVersionUID:
- 4517845269225218313L
-
Class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.NoOpStreamOperator extends AbstractStreamOperator<T> implements Serializable
- serialVersionUID:
- 4517845269225218313L
-
-
Package org.apache.flink.streaming.runtime.watermark
-
Class org.apache.flink.streaming.runtime.watermark.AbstractInternalWatermarkDeclaration extends Object implements Serializable
-
Serialized Fields
-
combinationPolicy
org.apache.flink.api.common.watermark.WatermarkCombinationPolicy combinationPolicy
-
defaultHandlingStrategy
org.apache.flink.api.common.watermark.WatermarkHandlingStrategy defaultHandlingStrategy
-
identifier
String identifier
-
isAligned
boolean isAligned
-
-
-
Class org.apache.flink.streaming.runtime.watermark.AlignableBoolWatermarkDeclaration extends org.apache.flink.api.common.watermark.BoolWatermarkDeclaration implements Serializable
-
Serialized Fields
-
isAligned
boolean isAligned
-
-
-
Class org.apache.flink.streaming.runtime.watermark.AlignableLongWatermarkDeclaration extends org.apache.flink.api.common.watermark.LongWatermarkDeclaration implements Serializable
-
Serialized Fields
-
isAligned
boolean isAligned
-
-
-
Class org.apache.flink.streaming.runtime.watermark.InternalBoolWatermarkDeclaration extends AbstractInternalWatermarkDeclaration<Boolean> implements Serializable
-
Class org.apache.flink.streaming.runtime.watermark.InternalLongWatermarkDeclaration extends AbstractInternalWatermarkDeclaration<Long> implements Serializable
-
-
Package org.apache.flink.streaming.util.keys
-
Class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
fields
int[] fields
-
-
Class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector extends Object implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.streaming.util.keys.KeySelectorUtil.OneKeySelector extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.streaming.util.typeutils
-
Class org.apache.flink.streaming.util.typeutils.FieldAccessor extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
fieldType
org.apache.flink.api.common.typeinfo.TypeInformation fieldType
-
-
Class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory extends Object implements Serializable
-