ramkrishna.s.vasudevan created FLINK-4461:
---------------------------------------------

             Summary: Ensure all the classes are tagged with suitable 
annotations
                 Key: FLINK-4461
                 URL: https://issues.apache.org/jira/browse/FLINK-4461
             Project: Flink
          Issue Type: Improvement
            Reporter: ramkrishna.s.vasudevan


Currently in Flink we have three annotations
Public
PublicEvolving
Internal.

But some of the classes though they are public they are not tagged. It may be 
even advanced features but still tagging them could help the user to know which 
are public facing and which are Internal API/interfaces. 

I just ran a sample util in streaming-java package and I got these
{code}
class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
class 
org.apache.flink.streaming.api.functions.source.FileMonitoringFunction$WatchType
interface org.apache.flink.streaming.api.functions.TimestampExtractor
class 
org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
class org.apache.flink.streaming.api.windowing.triggers.TriggerResult
class 
org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
class 
org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink$ExactlyOnceState
interface 
org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks
class 
org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
interface 
org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks
class 
org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
interface 
org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet$MergeFunction
class org.apache.flink.streaming.runtime.tasks.DefaultTimeServiceProvider
class 
org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
class org.apache.flink.streaming.api.functions.source.FileReadFunction
class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
class org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
class 
org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
class 
org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
class 
org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
class 
org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
interface org.apache.flink.streaming.api.functions.TimestampAssigner
class org.apache.flink.streaming.api.operators.StoppableStreamSource
class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
class 
org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
class org.apache.flink.streaming.util.HDFSCopyToLocal
class 
org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
class org.apache.flink.streaming.api.collector.selector.DirectedOutput
class org.apache.flink.streaming.runtime.tasks.TimeServiceProvider
class org.apache.flink.streaming.util.HDFSCopyFromLocal
class 
org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
{code}
These classes are simply not tagged.  In the above example TimeStampAssigner 
should fall in @Public tag I believe.




--
This message was sent by Atlassian JIRA
(v6.3.4#6332)

Reply via email to