Class FlowSystemMetadata
Object
org.apache.spark.sql.pipelines.graph.FlowSystemMetadata
- All Implemented Interfaces:
- Serializable,- org.apache.spark.internal.Logging,- SystemMetadata,- scala.Equals,- scala.Product
public class FlowSystemMetadata
extends Object
implements SystemMetadata, org.apache.spark.internal.Logging, scala.Product, Serializable
Represents the system metadata associated with a 
Flow.- See Also:
- 
Nested Class SummaryNested classes/interfaces inherited from interface org.apache.spark.internal.Loggingorg.apache.spark.internal.Logging.LogStringContext, org.apache.spark.internal.Logging.SparkShellLoggingFilter
- 
Constructor SummaryConstructorsConstructorDescriptionFlowSystemMetadata(PipelineUpdateContext context, Flow flow, DataflowGraph graph) 
- 
Method SummaryModifier and TypeMethodDescriptionabstract static Rapply(T1 v1, T2 v2, T3 v3) context()flow()graph()Returns the location for the most recent checkpoint of a given flow.scala.Option<String>Same aslatestCheckpointLocation()but returns None if the flow checkpoints directory does not exist.static StringtoString()Methods inherited from class java.lang.Objectequals, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface scala.EqualscanEqual, equalsMethods inherited from interface org.apache.spark.internal.LogginginitializeForcefully, initializeLogIfNecessary, initializeLogIfNecessary, initializeLogIfNecessary$default$2, isTraceEnabled, log, logBasedOnLevel, logDebug, logDebug, logDebug, logDebug, logError, logError, logError, logError, logInfo, logInfo, logInfo, logInfo, logName, LogStringContext, logTrace, logTrace, logTrace, logTrace, logWarning, logWarning, logWarning, logWarning, MDC, org$apache$spark$internal$Logging$$log_, org$apache$spark$internal$Logging$$log__$eq, withLogContextMethods inherited from interface scala.ProductproductArity, productElement, productElementName, productElementNames, productIterator, productPrefix
- 
Constructor Details- 
FlowSystemMetadata
 
- 
- 
Method Details- 
applypublic abstract static R apply(T1 v1, T2 v2, T3 v3) 
- 
toString
- 
context
- 
flow
- 
graph
- 
latestCheckpointLocationReturns the location for the most recent checkpoint of a given flow.
- 
latestCheckpointLocationOptSame aslatestCheckpointLocation()but returns None if the flow checkpoints directory does not exist.- Returns:
- (undocumented)
 
 
-