Uses of Class
uk.gov.gchq.gaffer.store.Store
- 
- 
Uses of Store in uk.gov.gchq.gaffer.accumulostoreSubclasses of Store in uk.gov.gchq.gaffer.accumulostore Modifier and Type Class Description classAccumuloStoreAn Accumulo Implementation of the Gaffer FrameworkclassSingleUseAccumuloStoreAnAccumuloStorethat deletes the underlying table each time it is initialised.
- 
Uses of Store in uk.gov.gchq.gaffer.accumulostore.operation.handlerMethods in uk.gov.gchq.gaffer.accumulostore.operation.handler with parameters of type Store 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 Element>GetAllElementsHandler. doOperation(GetAllElements operation, Context context, Store store)Iterable<? extends Element>GetElementsBetweenSetsHandler. doOperation(GetElementsBetweenSets operation, Context context, Store store)Deprecated.Iterable<? extends Element>GetElementsBetweenSetsPairsHandler. doOperation(GetElementsBetweenSetsPairs operation, Context context, Store store)Iterable<? extends Element>GetElementsHandler. doOperation(GetElements operation, Context context, Store store)Iterable<? extends Element>GetElementsInRangesHandler. doOperation(GetElementsInRanges operation, Context context, Store store)Iterable<? extends Element>GetElementsWithinSetHandler. doOperation(GetElementsWithinSet operation, Context context, Store store)Iterable<? extends Element>SummariseGroupOverRangesHandler. doOperation(SummariseGroupOverRanges operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.accumulostore.operation.hdfs.handlerMethods in uk.gov.gchq.gaffer.accumulostore.operation.hdfs.handler with parameters of type Store Modifier and Type Method Description VoidAddElementsFromHdfsHandler. doOperation(AddElementsFromHdfs operation, Context context, Store 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 Store in uk.gov.gchq.gaffer.accumulostore.operation.hdfs.handler.job.factoryMethods in uk.gov.gchq.gaffer.accumulostore.operation.hdfs.handler.job.factory with parameters of type Store Modifier and Type Method Description org.apache.hadoop.mapred.JobConfAccumuloAddElementsFromHdfsJobFactory. createJobConf(AddElementsFromHdfs operation, String mapperGeneratorClassName, Store store)org.apache.hadoop.mapred.JobConfAccumuloSampleDataForSplitPointsJobFactory. createJobConf(SampleDataForSplitPoints operation, String mapperGeneratorClassName, Store store)intAccumuloSampleDataForSplitPointsJobFactory. getExpectedNumberOfSplits(Store store)voidAccumuloAddElementsFromHdfsJobFactory. prepareStore(Store store)voidAccumuloAddElementsFromHdfsJobFactory. setupJob(org.apache.hadoop.mapreduce.Job job, AddElementsFromHdfs operation, String mapperGenerator, Store store)voidAccumuloSampleDataForSplitPointsJobFactory. setupJob(org.apache.hadoop.mapreduce.Job job, SampleDataForSplitPoints operation, String mapperGeneratorClassName, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.federated.simpleSubclasses of Store in uk.gov.gchq.gaffer.federated.simple Modifier and Type Class Description classFederatedStoreThe federated store implementation.
- 
Uses of Store in uk.gov.gchq.gaffer.federated.simple.operation.handlerMethods in uk.gov.gchq.gaffer.federated.simple.operation.handler with parameters of type Store 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 Store in uk.gov.gchq.gaffer.federated.simple.operation.handler.addMethods in uk.gov.gchq.gaffer.federated.simple.operation.handler.add with parameters of type Store Modifier and Type Method Description VoidAddGraphHandler. doOperation(AddGraph operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.federated.simple.operation.handler.getMethods in uk.gov.gchq.gaffer.federated.simple.operation.handler.get with parameters of type Store 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 Store in uk.gov.gchq.gaffer.federated.simple.operation.handler.miscMethods in uk.gov.gchq.gaffer.federated.simple.operation.handler.misc with parameters of type Store 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 Store in uk.gov.gchq.gaffer.federatedstoreSubclasses of Store in uk.gov.gchq.gaffer.federatedstore Modifier and Type Class Description classFederatedStoreA Store that encapsulates a collection of sub-graphs and executes operations against them and returns results as though it was a single graph.
- 
Uses of Store in uk.gov.gchq.gaffer.federatedstore.operation.handlerMethods in uk.gov.gchq.gaffer.federatedstore.operation.handler with parameters of type Store 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 Store in uk.gov.gchq.gaffer.federatedstore.operation.handler.implMethods in uk.gov.gchq.gaffer.federatedstore.operation.handler.impl with parameters of type Store 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 Store in uk.gov.gchq.gaffer.flink.operation.handlerMethods in uk.gov.gchq.gaffer.flink.operation.handler with parameters of type Store 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)Constructors in uk.gov.gchq.gaffer.flink.operation.handler with parameters of type Store Constructor Description GafferAdder(OP operation, Store store)GafferOutput(OP validatable, Store store)GafferSink(OP validatable, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.graphMethods in uk.gov.gchq.gaffer.graph with parameters of type Store Modifier and Type Method Description Graph.BuilderGraph.Builder. store(Store store)voidGraphConfig. validateAndUpdateGetFromCacheHook(Store store, Class<? extends Operation> operationClass, Class<? extends GetFromCacheHook> hookClass, String suffixFromProperties)Extracts and compares the cache suffixes of the suppliedOperation's handler andGetFromCacheHookresolver hook, throwsGraphHookSuffixExceptionif mismatched as writing and reading to cache will not behave correctly.
- 
Uses of Store in uk.gov.gchq.gaffer.hdfs.operation.handlerMethods in uk.gov.gchq.gaffer.hdfs.operation.handler with parameters of type Store Modifier and Type Method Description List<String>HdfsSplitStoreFromFileHandler. getSplits(SplitStoreFromFile operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.hdfs.operation.handler.job.factoryMethods in uk.gov.gchq.gaffer.hdfs.operation.handler.job.factory with parameters of type Store Modifier and Type Method Description org.apache.hadoop.mapred.JobConfJobFactory. createJobConf(O operation, String mapperGeneratorClassName, Store store)Creates anJobConfto be used for the add from hdfs.default List<org.apache.hadoop.mapreduce.Job>JobFactory. createJobs(O operation, Store store)Creates a job with the store specific job initialisation and then applies the operation specificJobInitialiser.intSampleDataForSplitPointsJobFactory. getExpectedNumberOfSplits(Store store)voidAddElementsFromHdfsJobFactory. prepareStore(Store store)Prepares the store for the add from hdfs.voidJobFactory. setupJob(org.apache.hadoop.mapreduce.Job job, O operation, String mapperGenerator, Store store)Sets up all parts of the Job to be used on the add from hdfs.
- 
Uses of Store in uk.gov.gchq.gaffer.hdfs.operation.handler.job.initialiserMethods in uk.gov.gchq.gaffer.hdfs.operation.handler.job.initialiser with parameters of type Store Modifier and Type Method Description voidAvroJobInitialiser. initialiseJob(org.apache.hadoop.mapreduce.Job job, MapReduce operation, Store store)voidJobInitialiser. initialiseJob(org.apache.hadoop.mapreduce.Job job, MapReduce operation, Store store)Initialises a job.voidTextJobInitialiser. initialiseJob(org.apache.hadoop.mapreduce.Job job, MapReduce operation, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.hdfs.operation.handler.job.toolConstructors in uk.gov.gchq.gaffer.hdfs.operation.handler.job.tool with parameters of type Store Constructor Description AddElementsFromHdfsTool(AddElementsFromHdfsJobFactory jobFactory, AddElementsFromHdfs operation, Store store)SampleDataAndCreateSplitsFileTool(SampleDataForSplitPointsJobFactory jobFactory, SampleDataForSplitPoints operation, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.mapstoreSubclasses of Store in uk.gov.gchq.gaffer.mapstore Modifier and Type Class Description classMapStoreclassSingleUseMapStoreA simpleMapStoreinstance suitable for testing.classSingleUseMapStoreWithoutVisibilitySupport
- 
Uses of Store in uk.gov.gchq.gaffer.mapstore.implMethods in uk.gov.gchq.gaffer.mapstore.impl with parameters of type Store 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)LongDeleteElementsHandler. doOperation(DeleteElements deleteElements, 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 Store in uk.gov.gchq.gaffer.operation.export.graphMethods in uk.gov.gchq.gaffer.operation.export.graph with parameters of type Store Modifier and Type Method Description GraphAuthorisedGraphForExportDelegate. createGraphInstance(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId, Map idAuths, User user)SchemaGraphForExportDelegate. resolveSchemaForGraph(Store store, Schema schema, List<String> parentSchemaIds, Pair<Schema,StoreProperties> existingGraphPair)StorePropertiesGraphForExportDelegate. resolveStorePropertiesForGraph(Store store, StoreProperties properties, String parentStorePropertiesId, Pair<Schema,StoreProperties> existingGraphPair)voidAuthorisedGraphForExportDelegate. validateGraph(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId, Pair<Schema,StoreProperties> existingGraphPair)voidGraphForExportDelegate. validateGraph(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId, Pair<Schema,StoreProperties> existingGraphPair)
- 
Uses of Store in uk.gov.gchq.gaffer.operation.export.graph.handlerMethods in uk.gov.gchq.gaffer.operation.export.graph.handler with parameters of type Store Modifier and Type Method Description static GraphGraphDelegate. createGraph(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId)GraphGraphDelegate. createGraphInstance(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId)GraphGraphDelegate. createGraphInstance(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId, GraphHook... hooks)GraphSerialisableGraphDelegate. createGraphSerialisable(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId)GraphSerialisableGraphDelegate. createGraphSerialisable(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId, GraphHook... hooks)BUILDERGraphDelegate.BaseBuilder. store(Store store)static voidGraphDelegate. validate(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId)static voidGraphDelegate. validate(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId, Pair<Schema,StoreProperties> existingGraphPair)voidGraphDelegate. validateGraph(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId)voidGraphDelegate. validateGraph(Store store, String graphId, Schema schema, StoreProperties storeProperties, List<String> parentSchemaIds, String parentStorePropertiesId, Pair<Schema,StoreProperties> existingGraphPair)
- 
Uses of Store in uk.gov.gchq.gaffer.proxystoreSubclasses of Store in uk.gov.gchq.gaffer.proxystore Modifier and Type Class Description classProxyStoreGafferProxyStoreimplementation.
- 
Uses of Store in uk.gov.gchq.gaffer.proxystore.operation.handlerMethods in uk.gov.gchq.gaffer.proxystore.operation.handler with parameters of type Store 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)OUTOperationChainHandler. doOperation(OperationChain<OUT> operationChain, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.spark.operation.handler.graphframeMethods in uk.gov.gchq.gaffer.spark.operation.handler.graphframe with parameters of type Store Modifier and Type Method Description org.graphframes.GraphFrameGetGraphFrameOfElementsHandler. doOperation(GetGraphFrameOfElements operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.sparkaccumulo.operation.handlerMethods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler with parameters of type Store Modifier and Type Method Description VoidAbstractImportKeyValuePairRDDToAccumuloHandler. doOperation(OP operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.dataframeMethods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.dataframe with parameters of type Store Modifier and Type Method Description org.apache.spark.sql.Dataset<org.apache.spark.sql.Row>GetDataFrameOfElementsHandler. doOperation(GetDataFrameOfElements operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.javarddMethods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.javardd with parameters of type Store 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, Store store)VoidSplitStoreFromJavaRDDOfElementsHandler. doOperation(SplitStoreFromJavaRDDOfElements operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalarddMethods in uk.gov.gchq.gaffer.sparkaccumulo.operation.handler.scalardd with parameters of type Store 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, Store store)VoidSplitStoreFromRDDOfElementsHandler. doOperation(SplitStoreFromRDDOfElements operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.storeMethods in uk.gov.gchq.gaffer.store that return Store Modifier and Type Method Description static StoreStore. createStore(String graphId, byte[] schema, Properties storeProperties)static StoreStore. createStore(String graphId, Schema schema, StoreProperties storeProperties)Method parameters in uk.gov.gchq.gaffer.store with type arguments of type Store Modifier and Type Method Description voidStoreProperties. setStoreClass(Class<? extends Store> storeClass)
- 
Uses of Store in uk.gov.gchq.gaffer.store.operationMethods in uk.gov.gchq.gaffer.store.operation with parameters of type Store Modifier and Type Method Description uk.gov.gchq.koryphe.ValidationResultOperationChainValidator. validate(OperationChain<?> operationChain, User user, Store store)Validate the providedOperationChainagainst theViewValidator.
- 
Uses of Store in uk.gov.gchq.gaffer.store.operation.handlerClasses in uk.gov.gchq.gaffer.store.operation.handler with type parameters of type Store Modifier and Type Class Description classAbstractGenerateSplitPointsFromSampleHandler<T,S extends Store>classAbstractSampleElementsForSplitPointsHandler<T,S extends Store>Methods in uk.gov.gchq.gaffer.store.operation.handler with parameters of type Store 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.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)<O> OperationChain<O>OperationChainHandler. prepareOperationChain(OperationChain<O> operationChain, Context context, Store store)voidSplitStoreFromFileHandler. splitStoreFromIterable(Iterable<String> splits, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.store.operation.handler.compareMethods in uk.gov.gchq.gaffer.store.operation.handler.compare with parameters of type Store 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 Store in uk.gov.gchq.gaffer.store.operation.handler.exportMethods in uk.gov.gchq.gaffer.store.operation.handler.export with parameters of type Store 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 Store in uk.gov.gchq.gaffer.store.operation.handler.export.localfileMethods in uk.gov.gchq.gaffer.store.operation.handler.export.localfile with parameters of type Store Modifier and Type Method Description LocalFileExporterImportFromLocalFileHandler. createExporter(ImportFromLocalFile importOp, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.store.operation.handler.export.setMethods in uk.gov.gchq.gaffer.store.operation.handler.export.set with parameters of type Store Modifier and Type Method Description SetExporterGetSetExportHandler. createExporter(GetSetExport export, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.store.operation.handler.functionMethods in uk.gov.gchq.gaffer.store.operation.handler.function with parameters of type Store Modifier and Type Method Description Iterable<? extends Element>AggregateHandler. doOperation(Aggregate operation, Context context, Store store)Iterable<? extends Element>FilterHandler. doOperation(Filter operation, Context context, Store store)Iterable<? extends Element>TransformHandler. doOperation(Transform operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.store.operation.handler.generateMethods in uk.gov.gchq.gaffer.store.operation.handler.generate with parameters of type Store 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 Store in uk.gov.gchq.gaffer.store.operation.handler.jobMethods in uk.gov.gchq.gaffer.store.operation.handler.job with parameters of type Store 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 Store in uk.gov.gchq.gaffer.store.operation.handler.joinMethods in uk.gov.gchq.gaffer.store.operation.handler.join with parameters of type Store Modifier and Type Method Description Iterable<? extends uk.gov.gchq.koryphe.tuple.MapTuple>JoinHandler. doOperation(Join<I> operation, Context context, Store store)
- 
Uses of Store in uk.gov.gchq.gaffer.store.operation.handler.namedMethods in uk.gov.gchq.gaffer.store.operation.handler.named with parameters of type Store 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 Store in uk.gov.gchq.gaffer.store.operation.handler.outputMethods in uk.gov.gchq.gaffer.store.operation.handler.output with parameters of type Store 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 Store in uk.gov.gchq.gaffer.store.operation.handler.utilMethods in uk.gov.gchq.gaffer.store.operation.handler.util with parameters of type Store 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.
 
-