Class ExecutionGraphID

  • All Implemented Interfaces:
    Serializable, Comparable<org.apache.flink.util.AbstractID>

    public class ExecutionGraphID
    extends org.apache.flink.util.AbstractID
    A class for statistically unique execution graph IDs.
    See Also:
    Serialized Form
    • Constructor Detail

      • ExecutionGraphID

        public ExecutionGraphID()
      • ExecutionGraphID

        public ExecutionGraphID​(byte[] bytes)
    • Method Detail

      • writeTo

        public void writeTo​(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf)
      • fromByteBuf

        public static ExecutionGraphID fromByteBuf​(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf)