- call(Tuple2<Long, Iterable<BigInteger>>) - Method in class org.apache.pirk.responder.wideskies.spark.EncColMultGroupedMapper
-
- call(BigInteger, BigInteger) - Method in class org.apache.pirk.responder.wideskies.spark.EncColMultReducer
-
- call(Tuple2<Integer, Iterable<List<BigInteger>>>) - Method in class org.apache.pirk.responder.wideskies.spark.EncRowCalc
-
- call(Tuple2<Integer, Tuple2<Iterable<Tuple2<Integer, BigInteger>>, Iterable<List<BigInteger>>>>) - Method in class org.apache.pirk.responder.wideskies.spark.EncRowCalcPrecomputedCache
-
- call(Iterator<Tuple2<Integer, Iterable<Tuple2<Integer, BigInteger>>>>) - Method in class org.apache.pirk.responder.wideskies.spark.ExpKeyFilenameMap
-
- call(Integer) - Method in class org.apache.pirk.responder.wideskies.spark.ExpTableGenerator
-
- call(MapWritable) - Method in class org.apache.pirk.responder.wideskies.spark.FilterData
-
- call(MapWritable) - Method in class org.apache.pirk.responder.wideskies.spark.HashSelectorsAndPartitionData
-
- call(Iterator<Tuple2<Long, BigInteger>>) - Method in class org.apache.pirk.responder.wideskies.spark.streaming.FinalResponseFunction
-
- call(String) - Method in interface org.apache.pirk.utils.FileIOUtils.Callable
-
- certainty(int) - Method in class org.apache.pirk.querier.wideskies.EncryptionPropertiesBuilder
-
- certainty - Static variable in class org.apache.pirk.test.utils.BaseTests
-
- CHAR - Static variable in class org.apache.pirk.schema.data.partitioner.PrimitiveTypePartitioner
-
- checkDNSHostnameQueryResults(List<QueryResponseJSON>, boolean, int, boolean, List<JSONObject>) - Static method in class org.apache.pirk.test.utils.BaseTests
-
- checkElement(String, Set<String>) - Static method in class org.apache.pirk.utils.StopListUtils
-
Checks to see whether an element (or subdomain of the given element) is contained in the HashSet If it is not in the set, returns true (keep)
- checkRangeQuery(boolean, String, String, String, DataSchema) - Static method in class org.apache.pirk.utils.QueryParserUtils
-
Method to handle ranges queries
- checkRecord(String, MapWritable, DataSchema) - Static method in class org.apache.pirk.utils.QueryParserUtils
-
Given a URI query string, checks to see if the given document satisfies the query
- checkRecord(String, Map<String, Object>, DataSchema) - Static method in class org.apache.pirk.utils.QueryParserUtils
-
- checkRecordWritableArrayWritable(String, MapWritable, DataSchema) - Static method in class org.apache.pirk.utils.QueryParserUtils
-
- cleanup(Reducer<LongWritable, Text, LongWritable, Text>.Context) - Method in class org.apache.pirk.responder.wideskies.mapreduce.ColumnMultReducer
-
- cleanup(Reducer<Text, Text, Text, Text>.Context) - Method in class org.apache.pirk.responder.wideskies.mapreduce.ExpTableReducer
-
- cleanup(Reducer<LongWritable, Text, LongWritable, Text>.Context) - Method in class org.apache.pirk.responder.wideskies.mapreduce.FinalResponseReducer
-
- cleanup(Mapper<Text, MapWritable, IntWritable, BytesArrayWritable>.Context) - Method in class org.apache.pirk.responder.wideskies.mapreduce.HashSelectorsAndPartitionDataMapper
-
- cleanup(Reducer<IntWritable, BytesArrayWritable, LongWritable, Text>.Context) - Method in class org.apache.pirk.responder.wideskies.mapreduce.RowCalcReducer
-
- cleanup(FileSystem, String, String, String) - Static method in class org.apache.pirk.test.distributed.DistributedTestDriver
-
Delete all necessary inputs, clean up
- clearRegistry() - Static method in class org.apache.pirk.schema.data.DataSchemaRegistry
-
Clear the registry
- clearRegistry() - Static method in class org.apache.pirk.schema.query.QuerySchemaRegistry
-
Clear the registry
- clone() - Method in class org.apache.pirk.query.wideskies.QueryInfo
-
- close() - Method in class org.apache.pirk.inputformat.hadoop.json.JSONRecordReader
-
- COLMULTREDUCEBYKEY - Static variable in class org.apache.pirk.responder.wideskies.ResponderProps
-
- ColumnMultMapper - Class in org.apache.pirk.responder.wideskies.mapreduce
-
Pass through mapper for encrypted column multiplication
- ColumnMultMapper() - Constructor for class org.apache.pirk.responder.wideskies.mapreduce.ColumnMultMapper
-
- ColumnMultReducer - Class in org.apache.pirk.responder.wideskies.mapreduce
-
Reducer to perform encrypted column multiplication
- ColumnMultReducer() - Constructor for class org.apache.pirk.responder.wideskies.mapreduce.ColumnMultReducer
-
- computeEncRow(Iterable<BytesArrayWritable>, Query, int, boolean, int, boolean) - Static method in class org.apache.pirk.responder.wideskies.common.ComputeEncryptedRow
-
Method to compute the encrypted row elements for a query from extracted data partitions in the form of Iterable
- computeEncRow(BytesArrayWritable, Query, int, int) - Static method in class org.apache.pirk.responder.wideskies.common.ComputeEncryptedRow
-
Method to compute the encrypted row elements for a query from extracted data partitions in the form of BytesArrayWritable
- computeEncRow(List<BigInteger>, Query, int, int) - Static method in class org.apache.pirk.responder.wideskies.common.ComputeEncryptedRow
-
Method to compute the encrypted row elements for a query from extracted data partitions in the form of ArrayList<>
- computeEncRow(BigInteger, Query, int, int) - Static method in class org.apache.pirk.responder.wideskies.common.ComputeEncryptedRow
-
- computeEncRowBI(Iterable<List<BigInteger>>, Query, int, boolean, int, boolean) - Static method in class org.apache.pirk.responder.wideskies.common.ComputeEncryptedRow
-
Method to compute the encrypted row elements for a query from extracted data partitions in the form of Iterable* * * *
- computeEncRowCacheInput(Iterable<List<BigInteger>>, HashMap<Integer, BigInteger>, int, boolean, int) - Static method in class org.apache.pirk.responder.wideskies.common.ComputeEncryptedRow
-
Method to compute the encrypted row elements for a query from extracted data partitions in the form of Iterable * * * * given
an input modular exponentiation table for the row
- ComputeEncryptedRow - Class in org.apache.pirk.responder.wideskies.common
-
Class to compute the encrypted row elements for a query from extracted data partitions
- ComputeEncryptedRow() - Constructor for class org.apache.pirk.responder.wideskies.common.ComputeEncryptedRow
-
- ComputeExpLookupTable - Class in org.apache.pirk.responder.wideskies.spark
-
Class to compute the distributed lookup table for the modular exponentiations used in performing a query
- ComputeExpLookupTable() - Constructor for class org.apache.pirk.responder.wideskies.spark.ComputeExpLookupTable
-
- computeExpTable(JavaSparkContext, FileSystem, BroadcastVars, Query, String, String) - Static method in class org.apache.pirk.responder.wideskies.spark.ComputeExpLookupTable
-
Method to create the distributed modular exponentiation lookup table in hdfs for a given Query
- computeExpTable(JavaSparkContext, FileSystem, BroadcastVars, Query, String, String, boolean) - Static method in class org.apache.pirk.responder.wideskies.spark.ComputeExpLookupTable
-
Method to create the distributed modular exponentiation lookup table in hdfs for a given Query
- ComputeResponse - Class in org.apache.pirk.responder.wideskies.spark
-
Master class for the PIR query spark application
- ComputeResponse(FileSystem) - Constructor for class org.apache.pirk.responder.wideskies.spark.ComputeResponse
-
- ComputeResponseTool - Class in org.apache.pirk.responder.wideskies.mapreduce
-
Tool for computing the PIR response in MapReduce
- ComputeResponseTool() - Constructor for class org.apache.pirk.responder.wideskies.mapreduce.ComputeResponseTool
-
- computeStandaloneResponse() - Method in class org.apache.pirk.responder.wideskies.standalone.Responder
-
Method to compute the standalone response
- ComputeStreamingResponse - Class in org.apache.pirk.responder.wideskies.spark.streaming
-
Master class for the PIR query spark streaming application
- ComputeStreamingResponse(FileSystem) - Constructor for class org.apache.pirk.responder.wideskies.spark.streaming.ComputeStreamingResponse
-
- containsElement(String) - Method in class org.apache.pirk.schema.data.DataSchema
-
Returns true if the data schema contains an element with the given name.
- containsWildcard(String) - Static method in class org.apache.pirk.utils.EpochDateParser
-
- convertSearchDate(String) - Static method in class org.apache.pirk.utils.EpochDateParser
-
- COUNTS - Static variable in class org.apache.pirk.utils.FileConst
-
- createESInput() - Static method in class org.apache.pirk.test.utils.Inputs
-
Creates Elasticsearch input
- createJSONDataElements() - Static method in class org.apache.pirk.test.utils.Inputs
-
Creates PIR JSON input
- createJSONInput(FileSystem) - Static method in class org.apache.pirk.test.utils.Inputs
-
Creates JSON input and writes to hdfs
- createQuerier(UUID, List<String>, Properties) - Static method in class org.apache.pirk.querier.wideskies.QuerierFactory
-
Generates a
Querier
containing the encrypted query.
- createQuerySchema(String, String, String, String, List<String>, List<String>, String) - Static method in class org.apache.pirk.test.utils.TestUtils
-
Creates the test query schema file
- createQuerySchema(String, String, String, String, List<String>, List<String>, String, boolean, FileSystem, boolean) - Static method in class org.apache.pirk.test.utils.TestUtils
-
Creates the test query schema file
- createQuerySchema(String, String, String, String, List<String>, List<String>, String, boolean, FileSystem, boolean, HashMap<String, String>) - Static method in class org.apache.pirk.test.utils.TestUtils
-
Creates the test query schema file
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pirk.inputformat.hadoop.json.JSONInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.pirk.inputformat.hadoop.json.JSONInputFormatBase
-
- createSchemaFiles(String) - Static method in class org.apache.pirk.test.utils.Inputs
-
Create and load the data and query schema files used for testing
- createSchemaFiles(FileSystem, boolean, String) - Static method in class org.apache.pirk.test.utils.Inputs
-
Create and load the data and query schema files used for testing
- createStopList(FileSystem, boolean) - Static method in class org.apache.pirk.test.utils.Inputs
-
Creates stoplist file
- createStormConf() - Static method in class org.apache.pirk.responder.wideskies.storm.PirkTopology
-
- CSVOutputUtils - Class in org.apache.pirk.utils
-
Utils class for CSV value output
- CSVOutputUtils() - Constructor for class org.apache.pirk.utils.CSVOutputUtils
-