Class InputOutputFormatVertex
- java.lang.Object
-
- org.apache.flink.runtime.jobgraph.JobVertex
-
- org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- All Implemented Interfaces:
Serializable
public class InputOutputFormatVertex extends JobVertex
A task vertex that runs an initialization and a finalization on the master. If necessary, it tries to deserialize input and output formats, and initialize and finalize them on master.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.runtime.jobgraph.JobVertex
JobVertex.FinalizeOnMasterContext, JobVertex.InitializeOnMasterContext
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.jobgraph.JobVertex
MAX_PARALLELISM_DEFAULT
-
-
Constructor Summary
Constructors Constructor Description InputOutputFormatVertex(String name)
InputOutputFormatVertex(String name, JobVertexID id, List<OperatorIDPair> operatorIDPairs)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
finalizeOnMaster(JobVertex.FinalizeOnMasterContext context)
A hook that can be overwritten by sub classes to implement logic that is called by the master after the job completed.String
getFormatDescription(OperatorID operatorID)
void
initializeOnMaster(JobVertex.InitializeOnMasterContext context)
A hook that can be overwritten by sub classes to implement logic that is called by the master when the job starts.void
setFormatDescription(OperatorID operatorID, String formatDescription)
-
Methods inherited from class org.apache.flink.runtime.jobgraph.JobVertex
addIntermediateDataSetIdToConsume, addOperatorCoordinator, connectNewDataSetAsInput, connectNewDataSetAsInput, connectNewDataSetAsInput, getCoLocationGroup, getConfiguration, getID, getInputs, getInputSplitSource, getIntermediateDataSetIdsToConsume, getInvokableClass, getInvokableClassName, getMaxParallelism, getMinResources, getName, getNumberOfInputs, getNumberOfProducedIntermediateDataSets, getOperatorCoordinators, getOperatorDescription, getOperatorIDs, getOperatorName, getOperatorPrettyName, getOrCreateResultDataSet, getParallelism, getPreferredResources, getProducedDataSets, getResultOptimizerProperties, getSlotSharingGroup, hasNoConnectedInputs, isAnyOutputBlocking, isDynamicParallelism, isInputVertex, isOutputVertex, isParallelismConfigured, isStoppable, isSupportsConcurrentExecutionAttempts, setDynamicParallelism, setInputSplitSource, setInvokableClass, setMaxParallelism, setName, setOperatorDescription, setOperatorName, setOperatorPrettyName, setParallelism, setParallelismConfigured, setResources, setResultOptimizerProperties, setSlotSharingGroup, setStrictlyCoLocatedWith, setSupportsConcurrentExecutionAttempts, toString, updateCoLocationGroup
-
-
-
-
Constructor Detail
-
InputOutputFormatVertex
public InputOutputFormatVertex(String name)
-
InputOutputFormatVertex
public InputOutputFormatVertex(String name, JobVertexID id, List<OperatorIDPair> operatorIDPairs)
-
-
Method Detail
-
initializeOnMaster
public void initializeOnMaster(JobVertex.InitializeOnMasterContext context) throws Exception
Description copied from class:JobVertex
A hook that can be overwritten by sub classes to implement logic that is called by the master when the job starts.- Overrides:
initializeOnMaster
in classJobVertex
- Parameters:
context
- Provides contextual information for the initialization- Throws:
Exception
- The method may throw exceptions which cause the job to fail immediately.
-
finalizeOnMaster
public void finalizeOnMaster(JobVertex.FinalizeOnMasterContext context) throws Exception
Description copied from class:JobVertex
A hook that can be overwritten by sub classes to implement logic that is called by the master after the job completed.- Overrides:
finalizeOnMaster
in classJobVertex
- Parameters:
context
- Provides contextual information for the initialization- Throws:
Exception
- The method may throw exceptions which cause the job to fail immediately.
-
getFormatDescription
public String getFormatDescription(OperatorID operatorID)
-
setFormatDescription
public void setFormatDescription(OperatorID operatorID, String formatDescription)
-
-