Class IgniteComputeEndpoint

  • 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.17.0",
                 scheme="ignite-compute",
                 title="Ignite Compute",
                 syntax="ignite-compute:endpointId",
                 category=COMPUTE,
                 producerOnly=true,
                 headersClass=IgniteConstants.class)
    public class IgniteComputeEndpoint
    extends AbstractIgniteEndpoint
    Run compute operations on an Ignite cluster. You can pass an IgniteCallable, an IgniteRunnable, an IgniteClosure, or collections of them, along with their parameters if necessary. This endpoint only supports producers.
    • 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.ignite.IgniteCompute createIgniteCompute()  
      org.apache.camel.Producer createProducer()  
      ClusterGroupExpression getClusterGroupExpression()
      Gets the cluster group expression.
      String getComputeName()
      Gets the name of the compute job, which will be set via IgniteCompute.withName(String).
      String getEndpointId()
      Gets the endpoint ID.
      IgniteComputeExecutionType getExecutionType()
      Gets the execution type of this producer.
      String getTaskName()
      Gets the task name, only applicable if using the IgniteComputeExecutionType.EXECUTE execution type.
      Long getTimeoutMillis()
      Gets the timeout interval for triggered jobs, in milliseconds, which will be set via IgniteCompute.withTimeout(long).
      void setClusterGroupExpression​(ClusterGroupExpression clusterGroupExpression)
      An expression that returns the Cluster Group for the IgniteCompute instance.
      void setComputeName​(String computeName)
      The name of the compute job, which will be set via IgniteCompute.withName(String).
      void setEndpointId​(String endpointId)
      The endpoint ID (not used).
      void setExecutionType​(IgniteComputeExecutionType executionType)
      The compute operation to perform.
      void setTaskName​(String taskName)
      The task name, only applicable if using the IgniteComputeExecutionType.EXECUTE execution type.
      void setTimeoutMillis​(Long timeoutMillis)
      The timeout interval for triggered jobs, in milliseconds, which will be set via IgniteCompute.withTimeout(long).
      • Methods inherited from class org.apache.camel.support.DefaultEndpoint

        configureConsumer, configureExchange, configurePollingConsumer, configureProperties, createAsyncProducer, createEndpointUri, createExchange, createExchange, createPollingConsumer, doInit, doStart, doStop, equals, getCamelContext, getComponent, 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

      • 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
      • createIgniteCompute

        public org.apache.ignite.IgniteCompute createIgniteCompute()
      • getEndpointId

        public String getEndpointId()
        Gets the endpoint ID.
      • setEndpointId

        public void setEndpointId​(String endpointId)
        The endpoint ID (not used).
      • getClusterGroupExpression

        public ClusterGroupExpression getClusterGroupExpression()
        Gets the cluster group expression.
      • setClusterGroupExpression

        public void setClusterGroupExpression​(ClusterGroupExpression clusterGroupExpression)
        An expression that returns the Cluster Group for the IgniteCompute instance.
      • setExecutionType

        public void setExecutionType​(IgniteComputeExecutionType executionType)
        The compute operation to perform. Possible values: CALL, BROADCAST, APPLY, EXECUTE, RUN, AFFINITY_CALL, AFFINITY_RUN. The component expects different payload types depending on the operation.
      • getComputeName

        public String getComputeName()
        Gets the name of the compute job, which will be set via IgniteCompute.withName(String).
      • setComputeName

        public void setComputeName​(String computeName)
        The name of the compute job, which will be set via IgniteCompute.withName(String).
      • getTimeoutMillis

        public Long getTimeoutMillis()
        Gets the timeout interval for triggered jobs, in milliseconds, which will be set via IgniteCompute.withTimeout(long).
      • setTimeoutMillis

        public void setTimeoutMillis​(Long timeoutMillis)
        The timeout interval for triggered jobs, in milliseconds, which will be set via IgniteCompute.withTimeout(long).