Uses of Class
uk.gov.gchq.gaffer.operation.OperationException
-
-
Uses of OperationException in uk.gov.gchq.gaffer.accumulostore.operation.handler
Methods in uk.gov.gchq.gaffer.accumulostore.operation.handler that throw OperationException Modifier and Type Method Description VoidAddElementsHandler. doOperation(AddElements operation, Context context, Store store)ObjectDeleteAllDataHandler. doOperation(DeleteAllData operation, Context context, Store store)LongDeleteElementsHandler. doOperation(DeleteElements operation, Context context, Store store)Iterable<? extends EntityId>GetAdjacentIdsHandler. doOperation(GetAdjacentIds operation, Context context, Store store)Iterable<? extends EntityId>GetAdjacentIdsHandler. doOperation(GetAdjacentIds op, User user, AccumuloStore store)Iterable<? extends Element>GetAllElementsHandler. doOperation(GetAllElements operation, Context context, Store store)Iterable<? extends Element>GetAllElementsHandler. doOperation(GetAllElements operation, User user, AccumuloStore store)Iterable<? extends Element>GetElementsBetweenSetsHandler. doOperation(GetElementsBetweenSets operation, Context context, Store store)Deprecated.Iterable<? extends Element>GetElementsBetweenSetsHandler. doOperation(GetElementsBetweenSets operation, User user, AccumuloStore store)Deprecated.Iterable<? extends Element>GetElementsBetweenSetsPairsHandler. doOperation(GetElementsBetweenSetsPairs operation, Context context, Store store)Iterable<? extends Element>GetElementsBetweenSetsPairsHandler. doOperation(GetElementsBetweenSetsPairs operation, User user, AccumuloStore store)Iterable<? extends Element>GetElementsHandler. doOperation(GetElements operation, Context context, Store store)Iterable<? extends Element>GetElementsHandler. doOperation(GetElements operation, User user, AccumuloStore store)Iterable<? extends Element>GetElementsInRangesHandler. doOperation(GetElementsInRanges operation, Context context, Store store)Iterable<? extends Element>GetElementsInRangesHandler. doOperation(GetElementsInRanges operation, User user, AccumuloStore store)Iterable<? extends Element>GetElementsWithinSetHandler. doOperation(GetElementsWithinSet operation, Context context, Store store)Iterable<? extends Element>GetElementsWithinSetHandler. doOperation(GetElementsWithinSet operation, User user, AccumuloStore store)Iterable<? extends Element>SummariseGroupOverRangesHandler. doOperation(SummariseGroupOverRanges operation, Context context, Store store)Iterable<? extends Element>SummariseGroupOverRangesHandler. doOperation(SummariseGroupOverRanges operation, User user, AccumuloStore store) -
Uses of OperationException in uk.gov.gchq.gaffer.accumulostore.operation.hdfs.handler
Methods in uk.gov.gchq.gaffer.accumulostore.operation.hdfs.handler that throw OperationException Modifier and Type Method Description voidAddElementsFromHdfsHandler. doOperation(AddElementsFromHdfs operation, Context context, AccumuloStore store)VoidAddElementsFromHdfsHandler. doOperation(AddElementsFromHdfs operation, Context context, Store store)voidImportAccumuloKeyValueFilesHandler. doOperation(ImportAccumuloKeyValueFiles operation, AccumuloStore store)VoidImportAccumuloKeyValueFilesHandler. doOperation(ImportAccumuloKeyValueFiles operation, Context context, Store store)VoidSampleDataForSplitPointsHandler. doOperation(SampleDataForSplitPoints operation, Context context, Store store)VoidSplitStoreFromIterableHandler. doOperation(SplitStoreFromIterable<String> operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.federated.simple.operation.handler
Methods in uk.gov.gchq.gaffer.federated.simple.operation.handler that throw OperationException Modifier and Type Method Description ObjectEitherOperationHandler. doOperation(O operation, Context context, Store store)If graph IDs are in the options the operation will be handled by aFederatedOperationHandler, otherwise the original handler will be used e.g.ObjectFederatedOperationHandler. doOperation(P operation, Context context, Store store)OFederatedOutputHandler. doOperation(P operation, Context context, Store store)Map<String,O>SeparateOutputHandler. doOperation(P operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.federated.simple.operation.handler.add
Methods in uk.gov.gchq.gaffer.federated.simple.operation.handler.add that throw OperationException Modifier and Type Method Description VoidAddGraphHandler. doOperation(AddGraph operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.federated.simple.operation.handler.get
Methods in uk.gov.gchq.gaffer.federated.simple.operation.handler.get that throw OperationException Modifier and Type Method Description Set<String>GetAllGraphIdsHandler. doOperation(GetAllGraphIds operation, Context context, Store store)Map<String,Object>GetAllGraphInfoHandler. doOperation(GetAllGraphInfo operation, Context context, Store store)SchemaGetSchemaHandler. doOperation(GetSchema operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.federated.simple.operation.handler.misc
Methods in uk.gov.gchq.gaffer.federated.simple.operation.handler.misc that throw OperationException Modifier and Type Method Description ObjectChangeGraphAccessHandler. doOperation(ChangeGraphAccess operation, Context context, Store store)ObjectChangeGraphIdHandler. doOperation(ChangeGraphId operation, Context context, Store store)ObjectRemoveGraphHandler. doOperation(RemoveGraph operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.federatedstore.operation.handler
Methods in uk.gov.gchq.gaffer.federatedstore.operation.handler that throw OperationException Modifier and Type Method Description VoidFederatedAddGraphHandlerParent. doOperation(OP operation, Context context, Store store)Iterable<? extends Element>FederatedDelegateToHandler. doOperation(InputOutput<Iterable<? extends Element>,Iterable<? extends Element>> operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.federatedstore.operation.handler.impl
Methods in uk.gov.gchq.gaffer.federatedstore.operation.handler.impl that throw OperationException Modifier and Type Method Description BooleanFederatedChangeGraphAccessHandler. doOperation(ChangeGraphAccess operation, Context context, Store store)BooleanFederatedChangeGraphIdHandler. doOperation(ChangeGraphId operation, Context context, Store store)Iterable<? extends String>FederatedGetAllGraphIDHandler. doOperation(GetAllGraphIds operation, Context context, Store store)Map<String,Object>FederatedGetAllGraphInfoHandler. doOperation(GetAllGraphInfo operation, Context context, Store store)VoidFederatedNoOutputHandler. doOperation(PAYLOAD operation, Context context, Store store)The Operation with no output is wrapped in a defaulted FederatedOperation and re-executed.ObjectFederatedOperationHandler. doOperation(FederatedOperation<INPUT,OUTPUT> operation, Context context, Store store)OUTPUTFederatedOutputHandler. doOperation(PAYLOAD operation, Context context, Store store)BooleanFederatedRemoveGraphAndDeleteAllDataHandler. doOperation(RemoveGraph operation, Context context, Store store)BooleanFederatedRemoveGraphHandler. doOperation(RemoveGraph operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.flink.operation.handler
Methods in uk.gov.gchq.gaffer.flink.operation.handler that throw OperationException Modifier and Type Method Description ObjectAddElementsFromFileHandler. doOperation(AddElementsFromFile op, Context context, Store store)ObjectAddElementsFromKafkaHandler. doOperation(AddElementsFromKafka op, Context context, Store store)ObjectAddElementsFromSocketHandler. doOperation(AddElementsFromSocket op, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.graph
Methods in uk.gov.gchq.gaffer.graph that throw OperationException Modifier and Type Method Description <O> GraphResult<O>Graph. execute(GraphRequest<O> request)Executes aGraphRequeston the graph and returns theGraphResult.<O> OGraph. execute(Output<O> operation, Context context)Performs the given output operation on the store.<O> OGraph. execute(Output<O> operation, User user)Performs the given output operation on the store.voidGraph. execute(Operation operation, Context context)Performs the given operation on the store.voidGraph. execute(Operation operation, User user)Performs the given operation on the store.GraphResult<JobDetail>Graph. executeJob(GraphRequest<?> request)Executes the givenGraphRequeston the graph as an asynchronous job and returns aGraphResultcontaining theJobDetails.JobDetailGraph. executeJob(Job job, Context context)Performs the given Job on the store.JobDetailGraph. executeJob(Job job, User user)Performs the given Job on the store.JobDetailGraph. executeJob(Operation operation, Context context)Performs the given operation job on the store.JobDetailGraph. executeJob(Operation operation, User user)Performs the given operation job on the store. -
Uses of OperationException in uk.gov.gchq.gaffer.hdfs.operation.handler
Methods in uk.gov.gchq.gaffer.hdfs.operation.handler that throw OperationException Modifier and Type Method Description List<String>HdfsSplitStoreFromFileHandler. getSplits(SplitStoreFromFile operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.hdfs.operation.handler.job.tool
Methods in uk.gov.gchq.gaffer.hdfs.operation.handler.job.tool that throw OperationException Modifier and Type Method Description intSampleDataAndCreateSplitsFileTool. run(String[] strings) -
Uses of OperationException in uk.gov.gchq.gaffer.mapstore.impl
Methods in uk.gov.gchq.gaffer.mapstore.impl that throw OperationException Modifier and Type Method Description VoidAddElementsHandler. doOperation(AddElements addElements, Context context, Store store)LongCountAllElementsDefaultViewHandler. doOperation(CountAllElementsDefaultView operation, Context context, Store store)ObjectDeleteAllDataHandler. doOperation(DeleteAllData operation, Context context, Store store)Iterable<? extends EntityId>GetAdjacentIdsHandler. doOperation(GetAdjacentIds operation, Context context, Store store)Iterable<? extends Element>GetAllElementsHandler. doOperation(GetAllElements operation, Context context, Store store)Iterable<Element>GetElementsHandler. doOperation(GetElements operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.operation.export
Methods in uk.gov.gchq.gaffer.operation.export that throw OperationException Modifier and Type Method Description voidExporter. add(String key, Iterable<?> results)Iterable<?>Exporter. get(String key) -
Uses of OperationException in uk.gov.gchq.gaffer.operation.export.graph
Methods in uk.gov.gchq.gaffer.operation.export.graph that throw OperationException Modifier and Type Method Description voidOtherGraphExporter. add(String key, Iterable<?> elements)Iterable<?>OtherGraphExporter. get(String key) -
Uses of OperationException in uk.gov.gchq.gaffer.operation.export.resultcache
Methods in uk.gov.gchq.gaffer.operation.export.resultcache that throw OperationException Modifier and Type Method Description voidGafferResultCacheExporter. add(String key, Iterable<?> values)Iterable<?>GafferResultCacheExporter. get(String key) -
Uses of OperationException in uk.gov.gchq.gaffer.operation.impl.export.localfile
Methods in uk.gov.gchq.gaffer.operation.impl.export.localfile that throw OperationException Modifier and Type Method Description voidLocalFileExporter. add(String filePath, Iterable<?> results)Iterable<String>LocalFileExporter. get(String filePath) -
Uses of OperationException in uk.gov.gchq.gaffer.proxystore
Methods in uk.gov.gchq.gaffer.proxystore that throw OperationException Modifier and Type Method Description JobDetailProxyStore. executeJob(OperationChain<?> operationChain, Context context)<O> OProxyStore. executeOpChainViaUrl(OperationChain<O> opChain, Context context) -
Uses of OperationException in uk.gov.gchq.gaffer.proxystore.operation.handler
Methods in uk.gov.gchq.gaffer.proxystore.operation.handler that throw OperationException Modifier and Type Method Description Map<String,Object>GetProxyPropertiesHandler. doOperation(GetProxyProperties operation, Context context, Store store)This implementation could work with with any store and properties but gets ONLY the Proxy Properties value from the Proxy store.StringGetProxyUrlHandler. doOperation(GetProxyUrl operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.rest.controller
Methods in uk.gov.gchq.gaffer.rest.controller that throw OperationException Modifier and Type Method Description Iterable<JobDetail>JobController. getAllDetails(org.springframework.http.HttpHeaders httpHeaders)JobDetailJobController. getDetails(org.springframework.http.HttpHeaders httpHeaders, String id)ObjectJobController. getResults(org.springframework.http.HttpHeaders httpHeaders, String id)org.springframework.http.ResponseEntity<JobDetail>JobController. scheduleJob(org.springframework.http.HttpHeaders httpHeaders, Job job)org.springframework.http.ResponseEntity<JobDetail>JobController. startJob(org.springframework.http.HttpHeaders httpHeaders, Operation operation) -
Uses of OperationException in uk.gov.gchq.gaffer.rest.service.v2
Methods in uk.gov.gchq.gaffer.rest.service.v2 that throw OperationException Modifier and Type Method Description javax.ws.rs.core.ResponseIJobServiceV2. details()javax.ws.rs.core.ResponseIJobServiceV2. details(String id)javax.ws.rs.core.ResponseJobServiceV2. details()javax.ws.rs.core.ResponseJobServiceV2. details(String id)javax.ws.rs.core.ResponseIJobServiceV2. executeJob(Job job)javax.ws.rs.core.ResponseIJobServiceV2. executeJob(Operation operation)javax.ws.rs.core.ResponseJobServiceV2. executeJob(Job job)javax.ws.rs.core.ResponseJobServiceV2. executeJob(Operation operation)javax.ws.rs.core.ResponseIJobServiceV2. results(String id)javax.ws.rs.core.ResponseJobServiceV2. results(String id) -
Uses of OperationException in uk.gov.gchq.gaffer.spark.operation.handler.graphframe
Methods in uk.gov.gchq.gaffer.spark.operation.handler.graphframe that throw OperationException Modifier and Type Method Description org.graphframes.GraphFrameGetGraphFrameOfElementsHandler. doOperation(GetGraphFrameOfElements operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler that throw OperationException Modifier and Type Method Description voidAbstractGetRDDHandler. addIterators(AccumuloStore accumuloStore, org.apache.hadoop.conf.Configuration conf, User user, OP operation)<INPUT_OP extends Operation & GraphFilters & Input<Iterable<? extends ElementId>>>
voidAbstractGetRDDHandler. addRanges(AccumuloStore accumuloStore, org.apache.hadoop.conf.Configuration conf, INPUT_OP operation)<INPUT_OP extends Operation & GraphFilters & Input<Iterable<? extends Pair<? extends ElementId,? extends ElementId>>>>
voidAbstractGetRDDHandler. addRangesFromPairs(AccumuloStore accumuloStore, org.apache.hadoop.conf.Configuration conf, INPUT_OP operation)voidAbstractImportKeyValuePairRDDToAccumuloHandler. doOperation(OP operation, Context context, AccumuloStore store)VoidAbstractImportKeyValuePairRDDToAccumuloHandler. doOperation(OP operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.dataframe
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.dataframe that throw OperationException Modifier and Type Method Description org.apache.spark.sql.Dataset<org.apache.spark.sql.Row>GetDataFrameOfElementsHandler. doOperation(GetDataFrameOfElements operation, Context context, AccumuloStore store)org.apache.spark.sql.Dataset<org.apache.spark.sql.Row>GetDataFrameOfElementsHandler. doOperation(GetDataFrameOfElements operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.javardd
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.javardd that throw OperationException Modifier and Type Method Description org.apache.spark.api.java.JavaRDD<Element>GetJavaRDDOfAllElementsHandler. doOperation(GetJavaRDDOfAllElements operation, Context context, Store store)org.apache.spark.api.java.JavaRDD<Element>GetJavaRDDOfElementsHandler. doOperation(GetJavaRDDOfElements operation, Context context, Store store)org.apache.spark.api.java.JavaRDD<Element>GetJavaRDDOfElementsInRangesHandler. doOperation(GetJavaRDDOfElementsInRanges operation, Context context, Store store)voidImportJavaRDDOfElementsHandler. doOperation(ImportJavaRDDOfElements operation, Context context, AccumuloStore store)VoidImportJavaRDDOfElementsHandler. doOperation(ImportJavaRDDOfElements operation, Context context, Store store)VoidSplitStoreFromJavaRDDOfElementsHandler. doOperation(SplitStoreFromJavaRDDOfElements operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd that throw OperationException Modifier and Type Method Description org.apache.spark.rdd.RDD<Element>GetRDDOfAllElementsHandler. doOperation(GetRDDOfAllElements operation, Context context, Store store)org.apache.spark.rdd.RDD<Element>GetRDDOfElementsHandler. doOperation(GetRDDOfElements operation, Context context, Store store)org.apache.spark.rdd.RDD<Element>GetRDDOfElementsInRangesHandler. doOperation(GetRDDOfElementsInRanges operation, Context context, Store store)voidImportRDDOfElementsHandler. doOperation(ImportRDDOfElements operation, Context context, AccumuloStore store)VoidImportRDDOfElementsHandler. doOperation(ImportRDDOfElements operation, Context context, Store store)VoidSplitStoreFromRDDOfElementsHandler. doOperation(SplitStoreFromRDDOfElements operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.sparkaccumulo.operation.utils
Methods in uk.gov.gchq.gaffer.sparkaccumulo.operation.utils that throw OperationException Modifier and Type Method Description static String[]AccumuloKeyRangePartitioner. getSplits(AccumuloStore store)Constructors in uk.gov.gchq.gaffer.sparkaccumulo.operation.utils that throw OperationException Constructor Description AccumuloKeyRangePartitioner(AccumuloStore store) -
Uses of OperationException in uk.gov.gchq.gaffer.store
Methods in uk.gov.gchq.gaffer.store that throw OperationException Modifier and Type Method Description <O> OStore. execute(Output<O> operation, Context context)Executes a given operation and returns the result.voidStore. execute(Operation operation, Context context)Executes a given operation and returns the result.JobDetailStore. executeJob(Job job, Context context)JobDetailStore. executeJob(Operation operation, Context context)Executes a given operation job and returns the job detail.ObjectStore. handleOperation(Operation operation, Context context) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler
Methods in uk.gov.gchq.gaffer.store.operation.handler that throw OperationException Modifier and Type Method Description ObjectWhileHandler. doDelegateOperation(Object input, Operation delegate, Context context, Store store)List<T>AbstractGenerateSplitPointsFromSampleHandler. doOperation(GenerateSplitPointsFromSample<T> operation, Context context, Store store)List<T>AbstractSampleElementsForSplitPointsHandler. doOperation(SampleElementsForSplitPoints<T> operation, Context context, Store store)VoidAddSchemaToLibraryHandler. doOperation(AddSchemaToLibrary operation, Context context, Store store)VoidAddStorePropertiesToLibraryHandler. doOperation(AddStorePropertiesToLibrary operation, Context context, Store store)GroupCountsCountGroupsHandler. doOperation(CountGroups operation, Context context, Store store)LongCountHandler. doOperation(Count operation, Context context, Store store)VoidDiscardOutputHandler. doOperation(DiscardOutput operation, Context context, Store store)Iterable<? extends O>ForEachHandler. doOperation(ForEach<I,O> forEach, Context context, Store store)StringGetFromEndpointHandler. doOperation(GetFromEndpoint operation, Context context, Store store)Map<String,String>GetGraphCreatedTimeHandler. doOperation(GetGraphCreatedTime operation, Context context, Store store)SchemaGetSchemaHandler. doOperation(GetSchema operation, Context context, Store store)Set<StoreTrait>GetTraitsHandler. doOperation(GetTraits operation, Context context, Store store)ObjectGetVariableHandler. doOperation(GetVariable operation, Context context, Store store)Map<String,Object>GetVariablesHandler. doOperation(GetVariables operation, Context context, Store store)Iterable<Walk>GetWalksHandler. doOperation(GetWalks getWalks, Context context, Store store)BooleanHasTraitHandler. doOperation(HasTrait operation, Context context, Store store)ObjectIfHandler. doOperation(If operation, Context context, Store store)Iterable<? extends T>LimitHandler. doOperation(Limit<T> operation, Context context, Store store)OMapHandler. doOperation(Map<I,O> operation, Context context, Store store)Handles theMapoperation.OUTOperationChainHandler. doOperation(OperationChain<OUT> operationChain, Context context, Store store)ObjectOperationHandler. doOperation(OP operation, Context context, Store store)Execute the givenOperation.OOperationWithSchemaHandler. doOperation(OP operation, Schema schema)OOutputOperationHandler. doOperation(OP operation, Context context, Store store)Execute the givenOutputoperation.TReduceHandler. doOperation(Reduce<T> operation, Context context, Store store)Handles theReduceoperation.IntegerScoreOperationChainHandler. doOperation(ScoreOperationChain operation, Context context, Store store)Returns the OperationChainLimiter score for the OperationChain provided.VoidSetVariableHandler. doOperation(SetVariable operation, Context context, Store store)VoidSplitStoreFromFileHandler. doOperation(SplitStoreFromFile operation, Context context, Store store)Iterable<? extends Element>ValidateHandler. doOperation(Validate operation, Context context, Store store)uk.gov.gchq.koryphe.ValidationResultValidateOperationChainHandler. doOperation(ValidateOperationChain operation, Context context, Store store)Returns aValidationResultfor the supplied OperationChain.ObjectWhileHandler. doOperation(While operation, Context context, Store store)List<String>SplitStoreFromFileHandler. getSplits(SplitStoreFromFile operation, Context context, Store store)booleanWhileHandler. isSatisfied(Object input, While operation, Context context, Store store)voidSplitStoreFromFileHandler. splitStoreFromIterable(Iterable<String> splits, Context context, Store store)voidWhileHandler. validateMaxRepeats(While operation) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.compare
Methods in uk.gov.gchq.gaffer.store.operation.handler.compare that throw OperationException Modifier and Type Method Description ElementMaxHandler. doOperation(Max operation, Context context, Store store)ElementMinHandler. doOperation(Min operation, Context context, Store store)Iterable<? extends Element>SortHandler. doOperation(Sort operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.export
Methods in uk.gov.gchq.gaffer.store.operation.handler.export that throw OperationException Modifier and Type Method Description ObjectExportOperationHandler. doOperation(EXPORT export, Context context, Store store)ObjectExportToHandler. doOperation(EXPORT export, Context context, Store store, EXPORTER exporter)Iterable<?>GetExportHandler. doOperation(EXPORT export, Context context, Store store, EXPORTER exporter)Map<String,Iterable<?>>GetExportsHandler. doOperation(GetExports getExports, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.function
Methods in uk.gov.gchq.gaffer.store.operation.handler.function that throw OperationException Modifier and Type Method Description Iterable<? extends Element>AggregateHandler. doOperation(Aggregate operation, Context context, Store store)Iterable<? extends Element>AggregateHandler. doOperation(Aggregate operation, Schema schema)Iterable<? extends Element>FilterHandler. doOperation(Filter operation, Context context, Store store)Iterable<? extends Element>FilterHandler. doOperation(Filter operation, Schema schema)Iterable<? extends Element>TransformHandler. doOperation(Transform operation, Context context, Store store)Iterable<? extends Element>TransformHandler. doOperation(Transform operation, Schema schema) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.generate
Methods in uk.gov.gchq.gaffer.store.operation.handler.generate that throw OperationException Modifier and Type Method Description Iterable<? extends Element>GenerateElementsHandler. doOperation(GenerateElements<OBJ> operation, Context context, Store store)Iterable<? extends OBJ>GenerateObjectsHandler. doOperation(GenerateObjects<OBJ> operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.job
Methods in uk.gov.gchq.gaffer.store.operation.handler.job that throw OperationException Modifier and Type Method Description VoidCancelScheduledJobHandler. doOperation(CancelScheduledJob operation, Context context, Store store)Iterable<JobDetail>GetAllJobDetailsHandler. doOperation(GetAllJobDetails operation, Context context, Store store)JobDetailGetJobDetailsHandler. doOperation(GetJobDetails operation, Context context, Store store)Iterable<?>GetJobResultsHandler. doOperation(GetJobResults operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.join
Methods in uk.gov.gchq.gaffer.store.operation.handler.join that throw OperationException Modifier and Type Method Description Iterable<? extends uk.gov.gchq.koryphe.tuple.MapTuple>JoinHandler. doOperation(Join<I> operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.named
Methods in uk.gov.gchq.gaffer.store.operation.handler.named that throw OperationException Modifier and Type Method Description VoidAddNamedOperationHandler. doOperation(AddNamedOperation operation, Context context, Store store)Adds a NamedOperation to a cache which must be specified in the operation declarations file.ObjectAddNamedViewHandler. doOperation(AddNamedView operation, Context context, Store store)Adds aNamedViewDetailto the NamedViewCache.VoidDeleteNamedOperationHandler. doOperation(DeleteNamedOperation operation, Context context, Store store)Deletes a NamedOperation from the cache specified in the Operations Declarations file (assuming the user has write privileges on the specified NamedOperation).VoidDeleteNamedViewHandler. doOperation(DeleteNamedView namedViewOp, Context context, Store store)Deletes a NamedView from the NamedViewCache.Iterable<NamedOperationDetail>GetAllNamedOperationsHandler. doOperation(GetAllNamedOperations operation, Context context, Store store)Retrieves all the Named Operations that a user is allowed to see.Iterable<NamedViewDetail>GetAllNamedViewsHandler. doOperation(GetAllNamedViews operation, Context context, Store store)Gets all NamedViews from the NamedViewCache.ObjectNamedOperationHandler. doOperation(NamedOperation<?,Object> operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.output
Methods in uk.gov.gchq.gaffer.store.operation.handler.output that throw OperationException Modifier and Type Method Description T[]ToArrayHandler. doOperation(ToArray<T> operation, Context context, Store store)Iterable<? extends String>ToCsvHandler. doOperation(ToCsv operation, Context context, Store store)Iterable<EntitySeed>ToEntitySeedsHandler. doOperation(ToEntitySeeds operation, Context context, Store store)List<T>ToListHandler. doOperation(ToList<T> operation, Context context, Store store)Iterable<? extends Map<String,Object>>ToMapHandler. doOperation(ToMap operation, Context context, Store store)Set<T>ToSetHandler. doOperation(ToSet<T> operation, Context context, Store store)List<? extends T>ToSingletonListHandler. doOperation(ToSingletonList<T> operation, Context context, Store store)Stream<? extends T>ToStreamHandler. doOperation(ToStream<T> operation, Context context, Store store)Iterable<Object>ToVerticesHandler. doOperation(ToVertices operation, Context context, Store store) -
Uses of OperationException in uk.gov.gchq.gaffer.store.operation.handler.util
Methods in uk.gov.gchq.gaffer.store.operation.handler.util that throw OperationException Modifier and Type Method Description static ObjectOperationHandlerUtil. getResultsOrNull(Operation op, Context context, Store store)Executes and operation on the store and returns the results or null. -
Uses of OperationException in uk.gov.gchq.gaffer.traffic
Methods in uk.gov.gchq.gaffer.traffic that throw OperationException Modifier and Type Method Description static voidQueries. main(String[] args) -
Uses of OperationException in uk.gov.gchq.gaffer.traffic.generator
Methods in uk.gov.gchq.gaffer.traffic.generator that throw OperationException Modifier and Type Method Description voidRoadTrafficDataLoader. load(File dataFile)voidRoadTrafficDataLoader. load(String csvString)voidRoadTrafficDataLoader. load(Supplier<Reader> readerSupplier)
-