Class FlinkEndpoint

  • All Implemented Interfaces:
    AutoCloseable, org.apache.camel.CamelContextAware, org.apache.camel.Endpoint, org.apache.camel.IsSingleton, org.apache.camel.Service, org.apache.camel.ShutdownableService, org.apache.camel.spi.HasId, org.apache.camel.StatefulService, org.apache.camel.SuspendableService

    @UriEndpoint(firstVersion="2.18.0",
                 scheme="flink",
                 title="Flink",
                 syntax="flink:endpointType",
                 producerOnly=true,
                 category={TRANSFORMATION,BIGDATA,STREAMS},
                 headersClass=FlinkConstants.class)
    public class FlinkEndpoint
    extends org.apache.camel.support.DefaultEndpoint
    Send DataSet jobs to an Apache Flink cluster.
    • Field Summary

      • Fields inherited from class org.apache.camel.support.service.BaseService

        BUILT, FAILED, INITIALIZED, INITIALIZING, lock, NEW, SHUTDOWN, SHUTTING_DOWN, STARTED, STARTING, status, STOPPED, STOPPING, SUSPENDED, SUSPENDING
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      org.apache.camel.Consumer createConsumer​(org.apache.camel.Processor processor)  
      org.apache.camel.Producer createProducer()  
      protected void doInit()  
      FlinkComponent getComponent()  
      org.apache.flink.api.java.DataSet getDataSet()  
      DataSetCallback getDataSetCallback()  
      org.apache.flink.streaming.api.datastream.DataStream getDataStream()  
      DataStreamCallback getDataStreamCallback()  
      boolean isCollect()  
      void setCollect​(boolean collect)
      Indicates if results should be collected or counted.
      void setDataSet​(org.apache.flink.api.java.DataSet ds)
      DataSet to compute against.
      void setDataSetCallback​(DataSetCallback dataSetCallback)
      Function performing action against a DataSet.
      void setDataStream​(org.apache.flink.streaming.api.datastream.DataStream ds)
      DataStream to compute against.
      void setDataStreamCallback​(DataStreamCallback dataStreamCallback)
      Function performing action against a DataStream.
      void setEndpointType​(EndpointType endpointType)
      Type of the endpoint (dataset, datastream).
      • Methods inherited from class org.apache.camel.support.DefaultEndpoint

        configureConsumer, configureExchange, configurePollingConsumer, configureProperties, createAsyncProducer, createEndpointUri, createExchange, createExchange, createPollingConsumer, doStart, doStop, equals, getCamelContext, getEndpointKey, getEndpointUri, getExceptionHandler, getExchangePattern, getId, getPollingConsumerBlockTimeout, getPollingConsumerQueueSize, hashCode, isAutowiredEnabled, isBridgeErrorHandler, isLazyStartProducer, isLenientProperties, isPollingConsumerBlockWhenFull, isPollingConsumerCopy, isSingleton, setAutowiredEnabled, setBridgeErrorHandler, setCamelContext, setComponent, setEndpointUri, setEndpointUriIfNotSpecified, setExceptionHandler, setExchangePattern, setLazyStartProducer, setPollingConsumerBlockTimeout, setPollingConsumerBlockWhenFull, setPollingConsumerCopy, setPollingConsumerQueueSize, setProperties, toString
      • Methods inherited from class org.apache.camel.support.service.BaseService

        build, doBuild, doFail, doLifecycleChange, doResume, doShutdown, doSuspend, fail, getStatus, init, isBuild, isInit, isNew, isRunAllowed, isShutdown, isStarted, isStarting, isStartingOrStarted, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, shutdown, start, stop, suspend
      • Methods inherited from interface org.apache.camel.Endpoint

        getEndpointBaseUri, isSingletonProducer
      • Methods inherited from interface org.apache.camel.Service

        build, close, init, start, stop
      • Methods inherited from interface org.apache.camel.ShutdownableService

        shutdown
      • Methods inherited from interface org.apache.camel.StatefulService

        getStatus, isRunAllowed, isStarted, isStarting, isStopped, isStopping, isSuspending
      • Methods inherited from interface org.apache.camel.SuspendableService

        isSuspended, resume, suspend
    • Method Detail

      • doInit

        protected void doInit()
                       throws Exception
        Overrides:
        doInit in class org.apache.camel.support.DefaultEndpoint
        Throws:
        Exception
      • createProducer

        public org.apache.camel.Producer createProducer()
                                                 throws Exception
        Throws:
        Exception
      • createConsumer

        public org.apache.camel.Consumer createConsumer​(org.apache.camel.Processor processor)
                                                 throws Exception
        Throws:
        Exception
      • getComponent

        public FlinkComponent getComponent()
        Overrides:
        getComponent in class org.apache.camel.support.DefaultEndpoint
      • setEndpointType

        public void setEndpointType​(EndpointType endpointType)
        Type of the endpoint (dataset, datastream).
      • getDataSet

        public org.apache.flink.api.java.DataSet getDataSet()
      • getDataStream

        public org.apache.flink.streaming.api.datastream.DataStream getDataStream()
      • setDataSet

        public void setDataSet​(org.apache.flink.api.java.DataSet ds)
        DataSet to compute against.
      • setDataStream

        public void setDataStream​(org.apache.flink.streaming.api.datastream.DataStream ds)
        DataStream to compute against.
      • setDataSetCallback

        public void setDataSetCallback​(DataSetCallback dataSetCallback)
        Function performing action against a DataSet.
      • setDataStreamCallback

        public void setDataStreamCallback​(DataStreamCallback dataStreamCallback)
        Function performing action against a DataStream.
      • isCollect

        public boolean isCollect()
      • setCollect

        public void setCollect​(boolean collect)
        Indicates if results should be collected or counted.