query
stringlengths
7
33.1k
document
stringlengths
7
335k
metadata
dict
negatives
listlengths
3
101
negative_scores
listlengths
3
101
document_score
stringlengths
3
10
document_rank
stringclasses
102 values
repeated .ChunkInfo chunks = 4;
public Builder setChunks( int index, entities.Torrent.ChunkInfo.Builder builderForValue) { if (chunksBuilder_ == null) { ensureChunksIsMutable(); chunks_.set(index, builderForValue.build()); onChanged(); } else { chunksBuilder_.setMessage(index, builderForValue.build()); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public Builder addChunks(entities.Torrent.ChunkInfo value) { if (chunksBuilder_ == null) { if (value == null) { throw new NullPointerException(); } ensureChunksIsMutable(); chunks_.add(value); onChanged(); } else { chunksBuilder_.addMessage(value); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public Builder addChunks( int index, entities.Torrent.ChunkInfo value) { if (chunksBuilder_ == null) { if (value == null) { throw new NullPointerException(); } ensureChunksIsMutable(); chunks_.add(index, value); onChanged(); } else { chunksBuilder_.addMessage(index, value); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public Builder addChunks( entities.Torrent.ChunkInfo.Builder builderForValue) { if (chunksBuilder_ == null) { ensureChunksIsMutable(); chunks_.add(builderForValue.build()); onChanged(); } else { chunksBuilder_.addMessage(builderForValue.build()); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public Builder addChunks( int index, entities.Torrent.ChunkInfo.Builder builderForValue) { if (chunksBuilder_ == null) { ensureChunksIsMutable(); chunks_.add(index, builderForValue.build()); onChanged(); } else { chunksBuilder_.addMessage(index, builderForValue.build()); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public Builder addAllChunks( java.lang.Iterable<? extends entities.Torrent.ChunkInfo> values) { if (chunksBuilder_ == null) { ensureChunksIsMutable(); com.google.protobuf.AbstractMessageLite.Builder.addAll( values, chunks_); onChanged(); } else { chunksBuilder_.addAllMessages(values); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public Builder clearChunks() { if (chunksBuilder_ == null) { chunks_ = java.util.Collections.emptyList(); bitField0_ = (bitField0_ & ~0x00000001); onChanged(); } else { chunksBuilder_.clear(); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public Builder removeChunks(int index) { if (chunksBuilder_ == null) { ensureChunksIsMutable(); chunks_.remove(index); onChanged(); } else { chunksBuilder_.remove(index); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public entities.Torrent.ChunkInfo.Builder getChunksBuilder( int index) { return getChunksFieldBuilder().getBuilder(index); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder( int index) { if (chunksBuilder_ == null) { return chunks_.get(index); } else { return chunksBuilder_.getMessageOrBuilder(index); } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.5390185
94
repeated .ChunkInfo chunks = 4;
public java.util.List<? extends entities.Torrent.ChunkInfoOrBuilder> getChunksOrBuilderList() { if (chunksBuilder_ != null) { return chunksBuilder_.getMessageOrBuilderList(); } else { return java.util.Collections.unmodifiableList(chunks_); } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public entities.Torrent.ChunkInfo.Builder addChunksBuilder() { return getChunksFieldBuilder().addBuilder( entities.Torrent.ChunkInfo.getDefaultInstance()); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public entities.Torrent.ChunkInfo.Builder addChunksBuilder( int index) { return getChunksFieldBuilder().addBuilder( index, entities.Torrent.ChunkInfo.getDefaultInstance()); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
repeated .ChunkInfo chunks = 4;
public java.util.List<entities.Torrent.ChunkInfo.Builder> getChunksBuilderList() { return getChunksFieldBuilder().getBuilderList(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunksCount();", "int getChunksCount();", "int getChunkSize();", "int getNumOfChunks();", "Builder spikesPerChunk(VariableAmount count);", "List<DownloadChunk> mo54445j(int i);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "void mo54414a(int i, List<DownloadChunk> list);", "void mo54426b(int i, List<DownloadChunk> list);", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "int getChunksLocationCount();", "entities.Torrent.ChunkInfo getChunks(int index);", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public void setChunked(boolean b) {\n/* 178 */ this.chunked = b;\n/* */ }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public int getChunkWidth() {\n return 256;\n }", "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "private Chunk generateChunk(int size) {\n String json;\n ObjectMapper objectMapper = new ObjectMapper();\n List<Record> recordList = new ArrayList<>();\n int i = 1;\n while (i <= size) {\n json = \"{ \\\"Price\\\" :\" + priceGenerator.nextDouble() * 100 + \" }\";\n try {\n recordList.add(new Record(String.valueOf(i), LocalDateTime.now(), objectMapper.readTree(json)));\n } catch (JsonProcessingException e) {\n log.error(\"Issue with the chunk generation: \" + e.getMessage());\n return null;\n }\n i++;\n\n }\n log.info(\"Generated Chunk :\");\n recordList.forEach((record) -> log.info(record.toString()));\n return new Chunk(recordList);\n }", "public int getChunkSize() {\n return chunkSize;\n }", "public static long getChunks() {\n return chunks;\n }", "public boolean isChunked() {\n/* 101 */ return this.chunked;\n/* */ }", "public int getChunksCount() {\n return chunksCount_;\n }", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "@Test\n public void testMultipleBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < noOfBlocks; i++) {\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1, i,\n i * blockSize, i == noOfBlocks - 1 ? testMeta.dataFile.length() : (i + 1) * blockSize, i == noOfBlocks - 1,\n i - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n for (int i = 0; i < messages.size(); i++) {\n\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "@java.lang.Override\n public int getChunksCount() {\n return chunks_.size();\n }", "void sendChunkRequest(int chunkX, int chunkY);", "@Test\n public void testStreamParsePubDev3401() throws IOException {\n final int chunkSize = 64 * 1024;\n ParseSetupV3 ps = new ParseSetupV3();\n ps.parse_type = \"CSV\";\n ps.chunk_size = chunkSize;\n // mock Parser\n final List<Integer> pcCalls = new LinkedList<>();\n Parser p = new Parser(new ParseSetup(ps), null) {\n @Override protected ParseWriter parseChunk(int cidx, ParseReader din, ParseWriter dout) {\n pcCalls.add(cidx);\n byte[] data = din.getChunkData(cidx);\n assert cidx <= 3;\n assert ((data != null) && (data.length == chunkSize)) || (cidx == 3);\n return null;\n }\n };\n // mock source InputStream, only used for \"back-channel\" chunk index signalling\n final Queue<Integer> cidxs = new LinkedList<>(Arrays.asList(1, 2, 3, 4));\n InputStream bvs = new InputStream() {\n @Override public int read() throws IOException { throw new UnsupportedOperationException(); }\n @Override public int read(byte[] b, int off, int len) throws IOException {\n assert b == null;\n return cidxs.remove();\n }\n };\n // mock StreamParseWriter\n MockStreamParseWriter w = new MockStreamParseWriter(chunkSize);\n // Vec made of 3 chunks\n Key k = FVecFactory.makeByteVec(\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize),\n RandomStringUtils.randomAscii(chunkSize)\n );\n try {\n ByteVec v = DKV.getGet(k);\n p.streamParseZip(v.openStream(null), w, bvs);\n assertEquals(\"Expected calls to parseChunk()\", Arrays.asList(0, 1, 2, 3), pcCalls);\n assertEquals(\"Expected calls to nextChunk()\", Arrays.asList(0, 1, 2), w._nchks);\n } finally {\n k.remove();\n }\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "void mo54417a(DownloadChunk downloadChunk);", "void setSpikesPerChunk(VariableAmount count);", "public boolean getChunking () {\n\treturn chunk;\n }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public int getChunksCount() {\n return chunksCount_;\n }", "boolean hasChunksCount();", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "@Test\n public void testChunkedOutputToChunkInput() throws Exception {\n final ChunkedInput<String> input = target().path(\"test\").request().get(new javax.ws.rs.core.GenericType<ChunkedInput<String>>() {});\n int counter = 0;\n String chunk;\n while ((chunk = input.read()) != null) {\n Assert.assertEquals((\"Unexpected value of chunk \" + counter), \"test\", chunk);\n counter++;\n } \n Assert.assertEquals(\"Unexpected numbed of received chunks.\", 3, counter);\n }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "String getChunkType();", "public int getChunkHeight() {\n return 256;\n }", "public void setChunking (boolean b) {\n\tchunk = b;\n }", "private static void generateWorld(){\n for(int i = 0; i < SIZE*SIZE; i++){\n new Chunk();\n }\n }", "public Builder setChunksCount(int value) {\n bitField0_ |= 0x00000002;\n chunksCount_ = value;\n onChanged();\n return this;\n }", "DataChunk nextChunk() throws RemoteException;", "entities.Torrent.ChunkResponse getChunkResponse();", "entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index);", "public int getChunkSize() {\r\n\t\treturn chunkSize;\r\n\t}", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "void handleChunk(char[] buff, int length) {\n\t\tint newlinePos = -1;\n\t\tfor (int pos = 0; pos < length; pos++) {\n\t\t\tif (buff[pos] == '\\n') {\n\t\t\t\tnewlinePos = pos;\n\t\t\t\tbreak;\n\t\t\t}\n\t\t}\n\t\tif (newlinePos > -1) {\n\t\t\tloaded.append(buff, 0, newlinePos);\n\t\t\tendLine();\n\t\t\tloaded.append(buff, newlinePos + 1, length - newlinePos - 1);\n\t\t} else {\n\t\t\tloaded.append(buff, 0, length);\n\t\t}\n\t}", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "public int getChunkSize () {\n return this.CHUNK_SIZE;\n }", "private void runGenerators(int chunkX, int chunkZ, Block[] ablock, byte[] abyte) {\n\t}", "public ChunkFiler() {}", "@Test\n public void testNonConsecutiveBlocks()\n {\n long blockSize = 1000;\n int noOfBlocks = (int)((testMeta.dataFile.length() / blockSize)\n + (((testMeta.dataFile.length() % blockSize) == 0) ? 0 : 1));\n\n testMeta.blockReader.beginWindow(1);\n\n for (int i = 0; i < 10; i++) {\n for (int j = 0; j < Math.ceil(noOfBlocks / 10.0); j++) {\n int blockNo = 10 * j + i;\n if (blockNo >= noOfBlocks) {\n continue;\n }\n BlockMetadata.FileBlockMetadata blockMetadata = new BlockMetadata.FileBlockMetadata(s3Directory + FILE_1,\n blockNo, blockNo * blockSize,\n blockNo == noOfBlocks - 1 ? testMeta.dataFile.length() : (blockNo + 1) * blockSize,\n blockNo == noOfBlocks - 1, blockNo - 1, testMeta.dataFile.length());\n testMeta.blockReader.blocksMetadataInput.process(blockMetadata);\n }\n }\n\n testMeta.blockReader.endWindow();\n\n List<Object> messages = testMeta.messageSink.collectedTuples;\n Assert.assertEquals(\"No of records\", testMeta.messages.size(), messages.size());\n\n Collections.sort(testMeta.messages, new Comparator<String[]>()\n {\n @Override\n public int compare(String[] rec1, String[] rec2)\n {\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n\n Collections.sort(messages, new Comparator<Object>()\n {\n @Override\n public int compare(Object object1, Object object2)\n {\n String[] rec1 = new String((byte[])object1).split(\",\");\n String[] rec2 = new String((byte[])object2).split(\",\");\n return compareStringArrayRecords(rec1, rec2);\n }\n });\n for (int i = 0; i < messages.size(); i++) {\n byte[] msg = (byte[])messages.get(i);\n Assert.assertTrue(\"line \" + i, Arrays.equals(new String(msg).split(\",\"), testMeta.messages.get(i)));\n }\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean hasChunksCount() {\n return ((bitField0_ & 0x00000002) == 0x00000002);\n }", "VariableAmount getSpikesPerChunk();", "ChunkCachingProtocol.Factory getChunkCachingProtocolFactory();", "entities.Torrent.ChunkRequest getChunkRequest();", "public int getChunkSize() {\n return chunkSize_;\n }", "public void readAllChunks(EndPoint endpoint) throws IOException, Pausable {\n IntList chunkRanges = new IntList(); // alternate numbers in this list refer to the start and end offsets of chunks.\n do {\n int n = readLine(endpoint); // read chunk size text into buffer\n int beg = iread;\n int size = parseChunkSize(buffer, iread - n, iread); // Parse size in hex, ignore extension\n if (size == 0)\n break;\n // If the chunk has not already been read in, do so\n fill(endpoint, iread, size+2 /*chunksize + CRLF*/);\n // record chunk start and end\n chunkRanges.add(beg); \n chunkRanges.add(beg + size); // without the CRLF\n iread += size + 2; // for the next round.\n } while (true);\n\n // / consolidate all chunkRanges\n if (chunkRanges.numElements == 0) {\n contentLength = 0;\n return;\n }\n contentOffset = chunkRanges.get(0); // first chunk's beginning\n int endOfLastChunk = chunkRanges.get(1); // first chunk's end\n\n byte[] bufa = buffer.array();\n for (int i = 2; i < chunkRanges.numElements; i += 2) {\n int beg = chunkRanges.get(i);\n int chunkSize = chunkRanges.get(i + 1) - beg;\n System.arraycopy(bufa, beg, bufa, endOfLastChunk, chunkSize);\n endOfLastChunk += chunkSize;\n }\n // TODO move all trailer stuff up\n contentLength = endOfLastChunk - contentOffset;\n \n // At this point, the contentOffset and contentLen give the entire content \n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "private static int getChunkSize(final int nChunks, final int nElements) {\n // Integer ceil\n return (nElements + nChunks - 1) / nChunks;\n }", "public Chunk() {\n }", "public int getChunksLocationCount() {\n return chunksLocation_.size();\n }", "public static void main(String[] args) {\n\tArrayList<Integer[]> chunks = new ArrayList<Integer[]>();\n\t\t\n\t\tfor(int x = -128; x<=128; x++){\n\t\t\t\n\t\t\tfor (int z = -128; z<=128; z++){\n\t\t\t\t\n\t\t\t\tif(x*x + z*z < 128*128){\n\t\t\t\t\t/*\n\t\t\t\t\t * Makes sure that there is no duplicate.\n\t\t\t\t\t */\n\t\t\t\t\tif(!HasChunks(new Integer[] {(int) x/ 16, (int) z/16}, chunks)){\n\t\t\t\t\t\t\n\t\t\t\t\t\tchunks.add(new Integer[] {(int) x/ 16, (int) z/16});\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t\t\n\t\t/*\n\t\t * The programm testd many chunks with many seeds in order to try to find the good location.\n\t\t */\n\t\tfor(long seed = 32000; seed<1000000L; seed++){\n\t\t \n\t\t\t//from chunk(-100;-100) to chunk(100;100) which is 4.10^4 chunks^2.seed^-1\n\t\t\tfor(int cx = -100; cx<=100; cx++){\n\t\t\t\tfor (int cz = -100; cz<=100; cz++){\n\t\t\t\n\t\t\t\t\tboolean flag = true;\n\t\t\t\t\t\t//browse the chunks which are in the 8chunk circle radius.\n\t\t\t\t\t\tfor(Integer[] ch: chunks){\n\t\t\t\t\t\t\t\n\t\t\t\t\t\t\tif(isSlimeChunk(seed, cx+ch[0], cz+ch[1])){\n\t\t\t\t\t\t\t\t\n\t\t\t\t\t\t\t\tflag = false;\n\t\t\t\t\t\t\t\tbreak;\n\t\t\t\t\t\t\t}\n\t\t\t\t\t\t}\n\t\t\t\t\t\t//no chunks contains slimechunks --> good location, we need to output the result.\n\t\t\t\t\t\tif(flag){\n\t\t\t\t\t\tSystem.out.println(\"Seed=\"+String.valueOf(seed)+\" ,ChunkX=\"+cx+\" ,ChunkZ\"+cz);\n\t\t\t\t\t\t\n\t\t\t\t\t\t}\n\t\t\t\t\t\n\t\t\t\t}\n\t\t\t}\n\t\t}\n\t\t\n\t}", "private void readHttpDataChunkByChunk(HttpPostRequestDecoder decoder) {\n try {\n while (decoder.hasNext()) {\n InterfaceHttpData data = decoder.next();\n if (data != null) {\n // check if current HttpData is a FileUpload and previously set as partial\n if (partialContent == data) {\n partialContent = null;\n }\n try {\n // new value\n writeHttpData(data);\n } finally {\n data.release();\n }\n }\n }\n // Check partial decoding for a FileUpload\n InterfaceHttpData data = decoder.currentPartialHttpData();\n if (data != null) {\n if (partialContent == null) {\n partialContent = (HttpData) data;\n }\n }\n } catch (HttpPostRequestDecoder.EndOfDataDecoderException e1) {\n // end\n }\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "void setChunkType(String aChunkType);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "@Override\n\tpublic int getMaxSpawnedInChunk() {\n\t\treturn EntityAttributes.CHUNK_LIMIT_1;\n\t}", "boolean hasChunkSize();", "boolean isSlimeChunk();", "default Builder spikesPerChunk(int count) {\n return spikesPerChunk(VariableAmount.fixed(count));\n }", "void setChunk(Boolean aIsChunk);", "public entities.Torrent.ChunkInfoOrBuilder getChunksOrBuilder(\n int index) {\n if (chunksBuilder_ == null) {\n return chunks_.get(index); } else {\n return chunksBuilder_.getMessageOrBuilder(index);\n }\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private void initChunkTables(final TablesInfo tables, final int firstCount,\n final int successiveCount) {\n final int totalSamples = (tables.stsz - firstCount);\n final float chunkAmount = totalSamples / (float) successiveCount;\n final int remainChunkOffset = (int) Math.ceil(chunkAmount);\n final boolean remain = remainChunkOffset != (int) chunkAmount;\n int index = 0;\n\n tables.stsc = 1;\n if (firstCount != successiveCount) {\n tables.stsc++;\n }\n if (remain) {\n tables.stsc++;\n }\n\n // stsc_table_entry = [first_chunk, samples_per_chunk, sample_description_index]\n tables.stscBEntries = new int[tables.stsc * 3];\n tables.stco = remainChunkOffset + 1; // total entries in chunk offset box\n\n tables.stscBEntries[index++] = 1;\n tables.stscBEntries[index++] = firstCount;\n tables.stscBEntries[index++] = 1;\n\n if (firstCount != successiveCount) {\n tables.stscBEntries[index++] = 2;\n tables.stscBEntries[index++] = successiveCount;\n tables.stscBEntries[index++] = 1;\n }\n\n if (remain) {\n tables.stscBEntries[index++] = remainChunkOffset + 1;\n tables.stscBEntries[index++] = totalSamples % successiveCount;\n tables.stscBEntries[index] = 1;\n }\n }", "@Test\n public void test() {\n bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n List<TokensLine> lines = bridge.chunk(\"file.txt\", new InputStreamReader(new ByteArrayInputStream(new byte[0]), StandardCharsets.UTF_8));\n\n assertThat(lines.size(), is(3));\n\n TokensLine line = lines.get(0);\n // 2 tokens on 1 line\n assertThat(line.getStartUnit(), is(1));\n assertThat(line.getEndUnit(), is(2));\n\n assertThat(line.getStartLine(), is(1));\n assertThat(line.getEndLine(), is(1));\n assertThat(line.getHashCode(), is(\"t1t2\".hashCode()));\n\n line = lines.get(1);\n // 1 token on 2 line\n assertThat(line.getStartUnit(), is(3));\n assertThat(line.getEndUnit(), is(3));\n\n assertThat(line.getStartLine(), is(2));\n assertThat(line.getEndLine(), is(2));\n assertThat(line.getHashCode(), is(\"t3\".hashCode()));\n\n line = lines.get(2);\n // 3 tokens on 4 line\n assertThat(line.getStartUnit(), is(4));\n assertThat(line.getEndUnit(), is(6));\n\n assertThat(line.getStartLine(), is(4));\n assertThat(line.getEndLine(), is(4));\n assertThat(line.getHashCode(), is(\"t1t3t3\".hashCode()));\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "public void mergeChunks(String fileName,int numChunks)\n {\n FileInputStream fInput;\n BufferedInputStream bufInput;\n BufferedOutputStream bufOutput;\n FileOutputStream fOutput;\n try\n { \n fOutput = new FileOutputStream(fileName);\n bufOutput = new BufferedOutputStream(fOutput); \n for(int i=0;i<numChunks;i++)\n {\n fInput = new FileInputStream(fileName+ \".chunk.\" + i);\n bufInput = new BufferedInputStream(fInput);\n int b;\n while((b=bufInput.read())!= -1)\n {\n bufOutput.write(b);\n }\n\n }\n bufOutput.close();\n }\n\t\tcatch(FileNotFoundException ex)\n {\n System.out.println(\"File Not Found\");\n }\n catch(IOException ex)\n {\n System.out.println(\"Some IOException occurred\");\n }\n }", "public int getChunkSize() {\n return chunkSize_;\n }" ]
[ "0.67930806", "0.67930806", "0.67899454", "0.6654797", "0.66464424", "0.65671897", "0.65612036", "0.65612036", "0.65612036", "0.65612036", "0.6432855", "0.6389131", "0.6388646", "0.6388646", "0.63311213", "0.6313464", "0.6313151", "0.6250478", "0.6222434", "0.6212164", "0.6208317", "0.6208317", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.6195882", "0.616113", "0.6121073", "0.6120777", "0.60767525", "0.6055177", "0.6049003", "0.6048348", "0.6011079", "0.59863573", "0.5982797", "0.5979438", "0.59664434", "0.5955178", "0.59335566", "0.59248525", "0.58630556", "0.5841949", "0.5805679", "0.5794726", "0.5776981", "0.5770205", "0.5760783", "0.5760591", "0.57453954", "0.5745015", "0.5717912", "0.5716544", "0.56923115", "0.5684082", "0.5678975", "0.56773555", "0.5668282", "0.5668282", "0.5652538", "0.56213593", "0.5615039", "0.5604932", "0.5604751", "0.5590173", "0.5586013", "0.55827063", "0.5569767", "0.5562768", "0.5551305", "0.5546152", "0.5534716", "0.55052906", "0.55052906", "0.55031693", "0.5486454", "0.54835945", "0.5475477", "0.5472386", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.5458741", "0.54535764", "0.5432046", "0.5429538", "0.5408323", "0.5407722", "0.5401188", "0.53937614", "0.5390185", "0.53901434", "0.53866833", "0.53819066", "0.5372146", "0.53718185", "0.5371598" ]
0.0
-1
.NodeId node = 1;
boolean hasNode();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
entities.Torrent.NodeId getNode();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.66503185
7
.NodeId node = 1;
entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.5917212
56
uint32 chunkIndex = 2;
int getChunkIndex();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "entities.Torrent.ChunkInfo getChunks(int index);", "int getNumOfChunks();", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "int getChunksCount();", "int getChunksCount();", "public int getHighestChunk() {\n return highestChunk_;\n }", "int getChunksLocationCount();", "public int getChunkWidth() {\n return 256;\n }", "public int currentChunkNum() {\n\t\treturn cp.chunk().getChunkNum();\n\t}", "int getChunkSize();", "public void nextTextureIndexX() {\n/* 245 */ this.particleTextureIndexX++;\n/* */ }", "List<DownloadChunk> mo54445j(int i);", "void sendChunkRequest(int chunkX, int chunkY);", "protected String _getChunkId(String id, int index) {\n\t\treturn id + \"[\" + index + \"]\";\n\t}", "public int getChunkHeight() {\n return 256;\n }", "public int getHighestChunk() {\n return highestChunk_;\n }", "String getChunkType();", "protected int getTextureIndex() {\n/* 83 */ return getData() & 0x7;\n/* */ }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public abstract int getNextBlock(int block) throws IOException;", "public int getInternalBlockLength()\r\n/* 40: */ {\r\n/* 41: 95 */ return 32;\r\n/* 42: */ }", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "public Builder setChunkIndex(int value) {\n\n chunkIndex_ = value;\n onChanged();\n return this;\n }", "public Builder setChunkIndex(int value) {\n\n chunkIndex_ = value;\n onChanged();\n return this;\n }", "boolean hasChunkId();", "void mo54426b(int i, List<DownloadChunk> list);", "@NotNull\n int getTrustedChunks();", "void mo54414a(int i, List<DownloadChunk> list);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "edu.usfca.cs.dfs.StorageMessages.StoreChunk getStoreChunk();", "public void map( Chunk bv ) { }", "int mo1684a(byte[] bArr, int i, int i2);", "private int getCol(int index) {\n return index & (chunkSize - 1);\n }", "int getBlockNumber();", "int getBlockNumber();", "public static long getChunks() {\n return chunks;\n }", "public Vector2i getChunkSize() {\n return new Vector2i(getChunkWidth(), getChunkHeight());\n }", "public void setChunkNumber(int chunkNumber) {\r\n\t\tthis.chunkNumber = chunkNumber;\r\n\t}", "private static void blockCoordsToChunkCoords(Vector3i pos) {\n pos.x >>= 4;\n pos.y >>= 4;\n pos.z >>= 4;\n }", "public void map( Chunk c ) { }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public boolean getChunking () {\n\treturn chunk;\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getStoreChunkLocation();", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "protected int nextInt(int p_75902_1_) {\n/* 135 */ int var2 = (int)((this.chunkSeed >> 24) % p_75902_1_);\n/* */ \n/* 137 */ if (var2 < 0)\n/* */ {\n/* 139 */ var2 += p_75902_1_;\n/* */ }\n/* */ \n/* 142 */ this.chunkSeed *= (this.chunkSeed * 6364136223846793005L + 1442695040888963407L);\n/* 143 */ this.chunkSeed += this.worldGenSeed;\n/* 144 */ return var2;\n/* */ }", "private int getIndex2(int val){\n return val/bucket;\n }", "@Override\r\n\tpublic int getIndexStep() {\n\t\t\r\n\t\treturn 2;\r\n\t}", "int getSplitIndex();", "public int getBlockSize()\n/* */ {\n/* 43 */ return this.blockSize;\n/* */ }", "int sampleOffset();", "public ChunkType getType();", "protected int arrayIndex(long windowIndex) {\n return (int) (windowIndex % length());\n }", "int getTotalBlockNum();", "void mo54417a(DownloadChunk downloadChunk);", "public int getChunkSize() {\n return chunkSize;\n }", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "public void map( Chunk cs[] ) { }", "int getBlockNumbers(int index);", "private int getImageBufferStartIndex(int trackNumber, FloppyDriveSide side) {\n return BYTES_PER_SECTOR * (SECTORS_PER_TRACK * (trackNumber * 2 + side.ordinal())\n + sectorIndex);\n }", "int getReadPosition(int index) {\n/* 170 */ return index - this.origPos + this.readerIndex;\n/* */ }", "private int getIndex(int val){\n return val%bucket;\n }", "@Test\n public void chunkPosShouldBePlayerPosDividedByChunkSizeWherePlayerAt1By1() {\n final int sideLengthOfBlock = 10;\n final int rowAmountInChunk = 11;\n\n MatcherAssert.assertThat(\n this.targetCompass(\n sideLengthOfBlock,\n rowAmountInChunk,\n new Point(1, 1)\n ).chunkPos(),\n CoreMatchers.equalTo(new Point(0, 0))\n );\n }", "private int key(int chunkX, int chunkY, int chunkZ) {\n if (chunkX >= 2048 || chunkX < 0 || chunkY >= 2048 || chunkY < 0 || chunkZ >= 4 || chunkZ < 0) {\n throw new IllegalArgumentException(\"ChunkX and ChunkY must range from 0-2047 inclusive (given x:\" + chunkX + \" and y: \" + chunkY + \"), and chunkZ must range from 0-3 inclusive (Given z: \" + chunkZ + \")\");\n }\n return (chunkZ << 30) | (chunkX << 15) | (chunkY);\n }", "protected int realIndex(int index) {\n return index & (buf.length -1);\n }", "private int getPmidIdx() {\n return this.colStartOffset + 2;\n }", "protected int populateBuffer()\n {\n interlock.beginReading();\n // System.out.println(\"populateBuffer: 2\");\n return byteBuffer.limit();\n }" ]
[ "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.6741172", "0.6741172", "0.66893995", "0.66893995", "0.6663846", "0.66030824", "0.66030824", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6410397", "0.6400465", "0.6379588", "0.6373404", "0.6315273", "0.6189685", "0.6189685", "0.61568904", "0.61450183", "0.6116205", "0.600113", "0.592988", "0.5924839", "0.590925", "0.5907171", "0.5883504", "0.5868158", "0.58488417", "0.5830536", "0.5826126", "0.58231753", "0.57997054", "0.57831234", "0.5773982", "0.57738006", "0.5764445", "0.57457185", "0.574476", "0.5730925", "0.57199186", "0.5672394", "0.5635696", "0.56262887", "0.56262887", "0.56262887", "0.56262887", "0.5625486", "0.56026787", "0.55572665", "0.5555952", "0.55468774", "0.55468774", "0.5537924", "0.5523598", "0.55199176", "0.55137247", "0.55008006", "0.5499361", "0.5496236", "0.54885995", "0.54849046", "0.54820436", "0.54716635", "0.54495907", "0.544209", "0.5437883", "0.5429143", "0.5428823", "0.5428345", "0.54230964", "0.5416858", "0.54106504", "0.5405122", "0.54008263", "0.5391839", "0.5382947", "0.53820837", "0.5372417", "0.5371448", "0.53595173", "0.53501457", "0.53402644", "0.53377634", "0.53344655" ]
0.785442
0
.Status status = 3;
int getStatusValue();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
.Status status = 3;
entities.Torrent.Status getStatus();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
string errorMessage = 4;
java.lang.String getErrorMessage();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.5886582", "0.5886582", "0.5886582", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.669224
14
string errorMessage = 4;
com.google.protobuf.ByteString getErrorMessageBytes();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.5886582", "0.5886582", "0.5886582", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.0
-1
Use NodeReplicationStatus.newBuilder() to construct.
private NodeReplicationStatus(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) { super(builder); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public entities.Torrent.NodeReplicationStatus.Builder addNodeStatusListBuilder() {\n return getNodeStatusListFieldBuilder().addBuilder(\n entities.Torrent.NodeReplicationStatus.getDefaultInstance());\n }", "public Builder addNodeStatusList(entities.Torrent.NodeReplicationStatus value) {\n if (nodeStatusListBuilder_ == null) {\n if (value == null) {\n throw new NullPointerException();\n }\n ensureNodeStatusListIsMutable();\n nodeStatusList_.add(value);\n onChanged();\n } else {\n nodeStatusListBuilder_.addMessage(value);\n }\n return this;\n }", "public Builder addAllNodeStatusList(\n java.lang.Iterable<? extends entities.Torrent.NodeReplicationStatus> values) {\n if (nodeStatusListBuilder_ == null) {\n ensureNodeStatusListIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, nodeStatusList_);\n onChanged();\n } else {\n nodeStatusListBuilder_.addAllMessages(values);\n }\n return this;\n }", "entities.Torrent.NodeReplicationStatusOrBuilder getNodeStatusListOrBuilder(\n int index);", "public entities.Torrent.NodeReplicationStatus.Builder addNodeStatusListBuilder(\n int index) {\n return getNodeStatusListFieldBuilder().addBuilder(\n index, entities.Torrent.NodeReplicationStatus.getDefaultInstance());\n }", "public Builder setNodeStatusList(\n int index, entities.Torrent.NodeReplicationStatus value) {\n if (nodeStatusListBuilder_ == null) {\n if (value == null) {\n throw new NullPointerException();\n }\n ensureNodeStatusListIsMutable();\n nodeStatusList_.set(index, value);\n onChanged();\n } else {\n nodeStatusListBuilder_.setMessage(index, value);\n }\n return this;\n }", "java.util.List<? extends entities.Torrent.NodeReplicationStatusOrBuilder>\n getNodeStatusListOrBuilderList();", "public Builder addNodeStatusList(\n int index, entities.Torrent.NodeReplicationStatus value) {\n if (nodeStatusListBuilder_ == null) {\n if (value == null) {\n throw new NullPointerException();\n }\n ensureNodeStatusListIsMutable();\n nodeStatusList_.add(index, value);\n onChanged();\n } else {\n nodeStatusListBuilder_.addMessage(index, value);\n }\n return this;\n }", "public entities.Torrent.NodeReplicationStatusOrBuilder getNodeStatusListOrBuilder(\n int index) {\n if (nodeStatusListBuilder_ == null) {\n return nodeStatusList_.get(index); } else {\n return nodeStatusListBuilder_.getMessageOrBuilder(index);\n }\n }", "public entities.Torrent.NodeReplicationStatus.Builder getNodeStatusListBuilder(\n int index) {\n return getNodeStatusListFieldBuilder().getBuilder(index);\n }", "@java.lang.Override\n public java.util.List<? extends entities.Torrent.NodeReplicationStatusOrBuilder>\n getNodeStatusListOrBuilderList() {\n return nodeStatusList_;\n }", "entities.Torrent.NodeReplicationStatus getNodeStatusList(int index);", "public java.util.List<? extends entities.Torrent.NodeReplicationStatusOrBuilder>\n getNodeStatusListOrBuilderList() {\n if (nodeStatusListBuilder_ != null) {\n return nodeStatusListBuilder_.getMessageOrBuilderList();\n } else {\n return java.util.Collections.unmodifiableList(nodeStatusList_);\n }\n }", "@java.lang.Override\n public entities.Torrent.NodeReplicationStatusOrBuilder getNodeStatusListOrBuilder(\n int index) {\n return nodeStatusList_.get(index);\n }", "@SuppressWarnings(\"unused\")\n private ReplicationStatusResponse() {\n this(false);\n }", "public Builder addNodeStatusList(\n entities.Torrent.NodeReplicationStatus.Builder builderForValue) {\n if (nodeStatusListBuilder_ == null) {\n ensureNodeStatusListIsMutable();\n nodeStatusList_.add(builderForValue.build());\n onChanged();\n } else {\n nodeStatusListBuilder_.addMessage(builderForValue.build());\n }\n return this;\n }", "public java.util.List<entities.Torrent.NodeReplicationStatus> getNodeStatusListList() {\n if (nodeStatusListBuilder_ == null) {\n return java.util.Collections.unmodifiableList(nodeStatusList_);\n } else {\n return nodeStatusListBuilder_.getMessageList();\n }\n }", "@java.lang.Override\n public java.util.List<entities.Torrent.NodeReplicationStatus> getNodeStatusListList() {\n return nodeStatusList_;\n }", "java.util.List<entities.Torrent.NodeReplicationStatus>\n getNodeStatusListList();", "public entities.Torrent.NodeReplicationStatus getNodeStatusList(int index) {\n if (nodeStatusListBuilder_ == null) {\n return nodeStatusList_.get(index);\n } else {\n return nodeStatusListBuilder_.getMessage(index);\n }\n }", "public Builder clearNodeStatusList() {\n if (nodeStatusListBuilder_ == null) {\n nodeStatusList_ = java.util.Collections.emptyList();\n bitField0_ = (bitField0_ & ~0x00000001);\n onChanged();\n } else {\n nodeStatusListBuilder_.clear();\n }\n return this;\n }", "public java.util.List<entities.Torrent.NodeReplicationStatus.Builder>\n getNodeStatusListBuilderList() {\n return getNodeStatusListFieldBuilder().getBuilderList();\n }", "@java.lang.Override\n public entities.Torrent.NodeReplicationStatus getNodeStatusList(int index) {\n return nodeStatusList_.get(index);\n }", "public StatusChecker(Node node){\n this.node=node;\n start();\n }", "public Builder addNodeStatusList(\n int index, entities.Torrent.NodeReplicationStatus.Builder builderForValue) {\n if (nodeStatusListBuilder_ == null) {\n ensureNodeStatusListIsMutable();\n nodeStatusList_.add(index, builderForValue.build());\n onChanged();\n } else {\n nodeStatusListBuilder_.addMessage(index, builderForValue.build());\n }\n return this;\n }", "public Builder setNodeStatusList(\n int index, entities.Torrent.NodeReplicationStatus.Builder builderForValue) {\n if (nodeStatusListBuilder_ == null) {\n ensureNodeStatusListIsMutable();\n nodeStatusList_.set(index, builderForValue.build());\n onChanged();\n } else {\n nodeStatusListBuilder_.setMessage(index, builderForValue.build());\n }\n return this;\n }", "public ReplicationObject() {\n }", "public Status(){\n this(StatusDescription.REGISTERED);\n }", "com.google.rpc.StatusOrBuilder getStatusOrBuilder();", "com.google.rpc.StatusOrBuilder getStatusOrBuilder();", "public Status() {\n }", "public Builder setStatus(TransmissionProtocol.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value.getNumber();\n onChanged();\n return this;\n }", "@java.lang.Override\n public int getNodeStatusListCount() {\n return nodeStatusList_.size();\n }", "public messages.Statusmessage.StatusMessage.Builder getStatusBuilder() {\n bitField0_ |= 0x00000040;\n onChanged();\n return getStatusFieldBuilder().getBuilder();\n }", "com.google.protobuf.UInt32ValueOrBuilder getStatusOrBuilder();", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public Builder setStatus(entities.Torrent.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n\n status_ = value.getNumber();\n onChanged();\n return this;\n }", "@Override\n public void statusUpdate(final String asgName, final ASGStatus newStatus, final boolean isReplication) {\n if (isReplication) {\n return;\n }\n for (final PeerEurekaNode node : peerEurekaNodes.getPeerEurekaNodes()) {\n replicateASGInfoToReplicaNodes(asgName, newStatus, node);\n\n }\n }", "public Status() {\n\n }", "public com.clarifai.grpc.api.status.Status.Builder getStatusBuilder() {\n \n onChanged();\n return getStatusFieldBuilder().getBuilder();\n }", "public com.clarifai.grpc.api.status.Status.Builder getStatusBuilder() {\n \n onChanged();\n return getStatusFieldBuilder().getBuilder();\n }", "public Builder setStatus(com.github.tomj0101.grpc.Status value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value.getNumber();\n onChanged();\n return this;\n }", "public OperationStatusResultInner() {\n }", "public TReturnStatus() {\n\n\t\tthis(TStatusCode.SRM_CUSTOM_STATUS);\n\t}", "private MonitoredTask getMonitorStatus() {\n if (monitorStatus == null) {\n monitorStatus = TaskMonitor.get()\n .createStatus(\"Cloning snapshot '\" + snapshot.getName() + \"' to table \" + getTableName());\n }\n return monitorStatus;\n }", "public int getNodeStatusListCount() {\n if (nodeStatusListBuilder_ == null) {\n return nodeStatusList_.size();\n } else {\n return nodeStatusListBuilder_.getCount();\n }\n }", "public Builder addStatus(int value) {\n ensureStatusIsMutable();\n status_.add(value);\n onChanged();\n return this;\n }", "int getReplicationCount();", "public static StatusType create() {\n\n return valueOf(0);\n }", "protected ClientStatus() {\n }", "com.clarifai.grpc.api.status.StatusOrBuilder getStatusOrBuilder();", "public CreateStatus()\n {\n super(new DataMap(), null);\n }", "@Override\n public void onNewClusterState(ClusterState state) {\n transportService.sendRequest(\n clusterService.localNode(),\n transportReplicaAction,\n replicaRequest,\n new ActionListenerResponseHandler<>(onCompletionListener, ReplicaResponse::new)\n );\n }", "public com.github.tomj0101.grpc.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n com.github.tomj0101.grpc.Status result = com.github.tomj0101.grpc.Status.valueOf(status_);\n return result == null ? com.github.tomj0101.grpc.Status.UNRECOGNIZED : result;\n }", "public static String getClusterStatusNodePath() {\n return String.join(\"/\", \"\", ROOT_NODE, COMPUTE_NODE, STATUS_NODE);\n }", "private BinStatusUpdate buildNewStatus() {\n return BinStatusUpdate.newBuilder()\n .setAmount(StuffAmount.newBuilder().setStuffAmount(bin.getStuffAmount()).build())\n .setStuff(Stuff.newBuilder().setStuffName(bin.getStuffName()).build())\n .setMaxAmount(bin.MAX_AMOUNT)\n .build();\n }", "public messages.Statusmessage.StatusMessageOrBuilder getStatusOrBuilder() {\n return status_;\n }", "protected Status() {\r\n\t\t;\r\n\t}", "public RegisterStatus() {\n registerStatus=NOT_REGISTERED;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "public com.github.tomj0101.grpc.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n com.github.tomj0101.grpc.Status result = com.github.tomj0101.grpc.Status.valueOf(status_);\n return result == null ? com.github.tomj0101.grpc.Status.UNRECOGNIZED : result;\n }", "public Builder clearStatus() {\n if (statusBuilder_ == null) {\n status_ = messages.Statusmessage.StatusMessage.getDefaultInstance();\n onChanged();\n } else {\n statusBuilder_.clear();\n }\n bitField0_ = (bitField0_ & ~0x00000040);\n return this;\n }", "public StatusComponent()\n {\n }", "private Status(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) {\n super(builder);\n }", "com.google.protobuf.ByteString\n getStatusBytes();", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "@java.lang.Override\n public entities.Torrent.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_);\n return result == null ? entities.Torrent.Status.UNRECOGNIZED : result;\n }", "public static OsVersionStatus compute(Controller controller) {\n Map<OsVersion, List<Node>> versions = new HashMap<>();\n\n // Always include all target versions\n controller.osVersions().forEach(osVersion -> versions.put(osVersion, new ArrayList<>()));\n\n for (SystemApplication application : SystemApplication.all()) {\n if (!application.isEligibleForOsUpgrades()) {\n continue; // Avoid querying applications that are not eligible for OS upgrades\n }\n for (ZoneApi zone : zonesToUpgrade(controller)) {\n controller.serviceRegistry().configServer().nodeRepository().list(zone.getId(), application.id()).stream()\n .filter(node -> OsUpgrader.eligibleForUpgrade(node, application))\n .map(node -> new Node(node.hostname(), node.currentOsVersion(), zone.getEnvironment(), zone.getRegionName()))\n .forEach(node -> {\n var version = new OsVersion(node.version(), zone.getCloudName());\n versions.putIfAbsent(version, new ArrayList<>());\n versions.get(version).add(node);\n });\n }\n }\n\n return new OsVersionStatus(versions);\n }", "public String replicationState() {\n return this.replicationState;\n }", "public TransmissionProtocol.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n TransmissionProtocol.Status result = TransmissionProtocol.Status.valueOf(status_);\n return result == null ? TransmissionProtocol.Status.UNRECOGNIZED : result;\n }", "com.google.protobuf.ByteString\n getStatusBytes();", "com.google.protobuf.ByteString\n getStatusBytes();", "StatusItem getReconcileStatus();", "public TransmissionProtocol.Status getStatus() {\n @SuppressWarnings(\"deprecation\")\n TransmissionProtocol.Status result = TransmissionProtocol.Status.valueOf(status_);\n return result == null ? TransmissionProtocol.Status.UNRECOGNIZED : result;\n }", "@SuppressWarnings(\"unused\")\r\n\tprivate LoginStatusBuilder(){}" ]
[ "0.7315252", "0.7260691", "0.65534204", "0.65425146", "0.6329711", "0.6302691", "0.6267726", "0.62320864", "0.6206241", "0.61621857", "0.6162092", "0.61382383", "0.6108109", "0.60579944", "0.6036796", "0.6015333", "0.60027605", "0.5790405", "0.57719713", "0.5635051", "0.55995756", "0.54630166", "0.5452249", "0.5350799", "0.5222808", "0.5196799", "0.49456728", "0.4925579", "0.49163637", "0.49163637", "0.48906642", "0.484444", "0.48371217", "0.4807969", "0.4791657", "0.4744293", "0.474307", "0.474307", "0.474307", "0.474307", "0.474307", "0.474307", "0.474307", "0.474307", "0.474307", "0.4740744", "0.4729735", "0.4720511", "0.4720511", "0.47043663", "0.47030652", "0.46988827", "0.46906662", "0.4638852", "0.462856", "0.458222", "0.4530587", "0.45220527", "0.4514701", "0.45070466", "0.45070282", "0.45056066", "0.44938943", "0.44849786", "0.44633538", "0.44630438", "0.44569784", "0.44553456", "0.44541958", "0.44541958", "0.44541958", "0.44541958", "0.44541958", "0.44541958", "0.44541958", "0.44541958", "0.44541958", "0.44537488", "0.4446414", "0.4443442", "0.44420013", "0.4437107", "0.44273183", "0.44273183", "0.44273183", "0.44273183", "0.44273183", "0.44273183", "0.44273183", "0.44273183", "0.44273183", "0.44272068", "0.4424173", "0.44241214", "0.44169858", "0.44115064", "0.44115064", "0.43977994", "0.43956336", "0.4393181" ]
0.768445
0
.NodeId node = 1;
@java.lang.Override public boolean hasNode() { return node_ != null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
@java.lang.Override public entities.Torrent.NodeId getNode() { return node_ == null ? entities.Torrent.NodeId.getDefaultInstance() : node_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
@java.lang.Override public entities.Torrent.NodeIdOrBuilder getNodeOrBuilder() { return getNode(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
uint32 chunkIndex = 2;
@java.lang.Override public int getChunkIndex() { return chunkIndex_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "entities.Torrent.ChunkInfo getChunks(int index);", "int getNumOfChunks();", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "int getChunksCount();", "int getChunksCount();", "public int getHighestChunk() {\n return highestChunk_;\n }", "int getChunksLocationCount();", "public int getChunkWidth() {\n return 256;\n }", "public int currentChunkNum() {\n\t\treturn cp.chunk().getChunkNum();\n\t}", "int getChunkSize();", "public void nextTextureIndexX() {\n/* 245 */ this.particleTextureIndexX++;\n/* */ }", "List<DownloadChunk> mo54445j(int i);", "void sendChunkRequest(int chunkX, int chunkY);", "protected String _getChunkId(String id, int index) {\n\t\treturn id + \"[\" + index + \"]\";\n\t}", "public int getChunkHeight() {\n return 256;\n }", "public int getHighestChunk() {\n return highestChunk_;\n }", "String getChunkType();", "protected int getTextureIndex() {\n/* 83 */ return getData() & 0x7;\n/* */ }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public abstract int getNextBlock(int block) throws IOException;", "public int getInternalBlockLength()\r\n/* 40: */ {\r\n/* 41: 95 */ return 32;\r\n/* 42: */ }", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "public Builder setChunkIndex(int value) {\n\n chunkIndex_ = value;\n onChanged();\n return this;\n }", "public Builder setChunkIndex(int value) {\n\n chunkIndex_ = value;\n onChanged();\n return this;\n }", "boolean hasChunkId();", "void mo54426b(int i, List<DownloadChunk> list);", "@NotNull\n int getTrustedChunks();", "void mo54414a(int i, List<DownloadChunk> list);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "edu.usfca.cs.dfs.StorageMessages.StoreChunk getStoreChunk();", "public void map( Chunk bv ) { }", "int mo1684a(byte[] bArr, int i, int i2);", "private int getCol(int index) {\n return index & (chunkSize - 1);\n }", "int getBlockNumber();", "int getBlockNumber();", "public static long getChunks() {\n return chunks;\n }", "public Vector2i getChunkSize() {\n return new Vector2i(getChunkWidth(), getChunkHeight());\n }", "public void setChunkNumber(int chunkNumber) {\r\n\t\tthis.chunkNumber = chunkNumber;\r\n\t}", "private static void blockCoordsToChunkCoords(Vector3i pos) {\n pos.x >>= 4;\n pos.y >>= 4;\n pos.z >>= 4;\n }", "public void map( Chunk c ) { }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public boolean getChunking () {\n\treturn chunk;\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getStoreChunkLocation();", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "protected int nextInt(int p_75902_1_) {\n/* 135 */ int var2 = (int)((this.chunkSeed >> 24) % p_75902_1_);\n/* */ \n/* 137 */ if (var2 < 0)\n/* */ {\n/* 139 */ var2 += p_75902_1_;\n/* */ }\n/* */ \n/* 142 */ this.chunkSeed *= (this.chunkSeed * 6364136223846793005L + 1442695040888963407L);\n/* 143 */ this.chunkSeed += this.worldGenSeed;\n/* 144 */ return var2;\n/* */ }", "private int getIndex2(int val){\n return val/bucket;\n }", "@Override\r\n\tpublic int getIndexStep() {\n\t\t\r\n\t\treturn 2;\r\n\t}", "int getSplitIndex();", "public int getBlockSize()\n/* */ {\n/* 43 */ return this.blockSize;\n/* */ }", "int sampleOffset();", "public ChunkType getType();", "protected int arrayIndex(long windowIndex) {\n return (int) (windowIndex % length());\n }", "int getTotalBlockNum();", "void mo54417a(DownloadChunk downloadChunk);", "public int getChunkSize() {\n return chunkSize;\n }", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "public void map( Chunk cs[] ) { }", "int getBlockNumbers(int index);", "private int getImageBufferStartIndex(int trackNumber, FloppyDriveSide side) {\n return BYTES_PER_SECTOR * (SECTORS_PER_TRACK * (trackNumber * 2 + side.ordinal())\n + sectorIndex);\n }", "int getReadPosition(int index) {\n/* 170 */ return index - this.origPos + this.readerIndex;\n/* */ }", "private int getIndex(int val){\n return val%bucket;\n }", "@Test\n public void chunkPosShouldBePlayerPosDividedByChunkSizeWherePlayerAt1By1() {\n final int sideLengthOfBlock = 10;\n final int rowAmountInChunk = 11;\n\n MatcherAssert.assertThat(\n this.targetCompass(\n sideLengthOfBlock,\n rowAmountInChunk,\n new Point(1, 1)\n ).chunkPos(),\n CoreMatchers.equalTo(new Point(0, 0))\n );\n }", "private int key(int chunkX, int chunkY, int chunkZ) {\n if (chunkX >= 2048 || chunkX < 0 || chunkY >= 2048 || chunkY < 0 || chunkZ >= 4 || chunkZ < 0) {\n throw new IllegalArgumentException(\"ChunkX and ChunkY must range from 0-2047 inclusive (given x:\" + chunkX + \" and y: \" + chunkY + \"), and chunkZ must range from 0-3 inclusive (Given z: \" + chunkZ + \")\");\n }\n return (chunkZ << 30) | (chunkX << 15) | (chunkY);\n }", "protected int realIndex(int index) {\n return index & (buf.length -1);\n }", "private int getPmidIdx() {\n return this.colStartOffset + 2;\n }", "protected int populateBuffer()\n {\n interlock.beginReading();\n // System.out.println(\"populateBuffer: 2\");\n return byteBuffer.limit();\n }" ]
[ "0.785442", "0.785442", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.6741172", "0.6741172", "0.66893995", "0.66893995", "0.6663846", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6410397", "0.6400465", "0.6379588", "0.6373404", "0.6315273", "0.6189685", "0.6189685", "0.61568904", "0.61450183", "0.6116205", "0.600113", "0.592988", "0.5924839", "0.590925", "0.5907171", "0.5883504", "0.5868158", "0.58488417", "0.5830536", "0.5826126", "0.58231753", "0.57997054", "0.57831234", "0.5773982", "0.57738006", "0.5764445", "0.57457185", "0.574476", "0.5730925", "0.57199186", "0.5672394", "0.5635696", "0.56262887", "0.56262887", "0.56262887", "0.56262887", "0.5625486", "0.56026787", "0.55572665", "0.5555952", "0.55468774", "0.55468774", "0.5537924", "0.5523598", "0.55199176", "0.55137247", "0.55008006", "0.5499361", "0.5496236", "0.54885995", "0.54849046", "0.54820436", "0.54716635", "0.54495907", "0.544209", "0.5437883", "0.5429143", "0.5428823", "0.5428345", "0.54230964", "0.5416858", "0.54106504", "0.5405122", "0.54008263", "0.5391839", "0.5382947", "0.53820837", "0.5372417", "0.5371448", "0.53595173", "0.53501457", "0.53402644", "0.53377634", "0.53344655" ]
0.66030824
14
.Status status = 3;
@java.lang.Override public int getStatusValue() { return status_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
.Status status = 3;
@java.lang.Override public entities.Torrent.Status getStatus() { @SuppressWarnings("deprecation") entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_); return result == null ? entities.Torrent.Status.UNRECOGNIZED : result; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
string errorMessage = 4;
@java.lang.Override public java.lang.String getErrorMessage() { java.lang.Object ref = errorMessage_; if (ref instanceof java.lang.String) { return (java.lang.String) ref; } else { com.google.protobuf.ByteString bs = (com.google.protobuf.ByteString) ref; java.lang.String s = bs.toStringUtf8(); errorMessage_ = s; return s; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.5886582", "0.5886582", "0.5886582", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.0
-1
string errorMessage = 4;
@java.lang.Override public com.google.protobuf.ByteString getErrorMessageBytes() { java.lang.Object ref = errorMessage_; if (ref instanceof java.lang.String) { com.google.protobuf.ByteString b = com.google.protobuf.ByteString.copyFromUtf8( (java.lang.String) ref); errorMessage_ = b; return b; } else { return (com.google.protobuf.ByteString) ref; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.5886582", "0.5886582", "0.5886582", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.0
-1
.NodeId node = 1;
public boolean hasNode() { return nodeBuilder_ != null || node_ != null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public entities.Torrent.NodeId getNode() { if (nodeBuilder_ == null) { return node_ == null ? entities.Torrent.NodeId.getDefaultInstance() : node_; } else { return nodeBuilder_.getMessage(); } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public Builder setNode(entities.Torrent.NodeId value) { if (nodeBuilder_ == null) { if (value == null) { throw new NullPointerException(); } node_ = value; onChanged(); } else { nodeBuilder_.setMessage(value); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public Builder setNode( entities.Torrent.NodeId.Builder builderForValue) { if (nodeBuilder_ == null) { node_ = builderForValue.build(); onChanged(); } else { nodeBuilder_.setMessage(builderForValue.build()); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public Builder mergeNode(entities.Torrent.NodeId value) { if (nodeBuilder_ == null) { if (node_ != null) { node_ = entities.Torrent.NodeId.newBuilder(node_).mergeFrom(value).buildPartial(); } else { node_ = value; } onChanged(); } else { nodeBuilder_.mergeFrom(value); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public Builder clearNode() { if (nodeBuilder_ == null) { node_ = null; onChanged(); } else { node_ = null; nodeBuilder_ = null; } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public entities.Torrent.NodeId.Builder getNodeBuilder() { onChanged(); return getNodeFieldBuilder().getBuilder(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public entities.Torrent.NodeIdOrBuilder getNodeOrBuilder() { if (nodeBuilder_ != null) { return nodeBuilder_.getMessageOrBuilder(); } else { return node_ == null ? entities.Torrent.NodeId.getDefaultInstance() : node_; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
private com.google.protobuf.SingleFieldBuilderV3< entities.Torrent.NodeId, entities.Torrent.NodeId.Builder, entities.Torrent.NodeIdOrBuilder> getNodeFieldBuilder() { if (nodeBuilder_ == null) { nodeBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< entities.Torrent.NodeId, entities.Torrent.NodeId.Builder, entities.Torrent.NodeIdOrBuilder>( getNode(), getParentForChildren(), isClean()); node_ = null; } return nodeBuilder_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
uint32 chunkIndex = 2;
@java.lang.Override public int getChunkIndex() { return chunkIndex_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "entities.Torrent.ChunkInfo getChunks(int index);", "int getNumOfChunks();", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "int getChunksCount();", "int getChunksCount();", "public int getHighestChunk() {\n return highestChunk_;\n }", "int getChunksLocationCount();", "public int getChunkWidth() {\n return 256;\n }", "public int currentChunkNum() {\n\t\treturn cp.chunk().getChunkNum();\n\t}", "int getChunkSize();", "public void nextTextureIndexX() {\n/* 245 */ this.particleTextureIndexX++;\n/* */ }", "List<DownloadChunk> mo54445j(int i);", "void sendChunkRequest(int chunkX, int chunkY);", "protected String _getChunkId(String id, int index) {\n\t\treturn id + \"[\" + index + \"]\";\n\t}", "public int getChunkHeight() {\n return 256;\n }", "public int getHighestChunk() {\n return highestChunk_;\n }", "String getChunkType();", "protected int getTextureIndex() {\n/* 83 */ return getData() & 0x7;\n/* */ }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public abstract int getNextBlock(int block) throws IOException;", "public int getInternalBlockLength()\r\n/* 40: */ {\r\n/* 41: 95 */ return 32;\r\n/* 42: */ }", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "public Builder setChunkIndex(int value) {\n\n chunkIndex_ = value;\n onChanged();\n return this;\n }", "public Builder setChunkIndex(int value) {\n\n chunkIndex_ = value;\n onChanged();\n return this;\n }", "boolean hasChunkId();", "void mo54426b(int i, List<DownloadChunk> list);", "@NotNull\n int getTrustedChunks();", "void mo54414a(int i, List<DownloadChunk> list);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "edu.usfca.cs.dfs.StorageMessages.StoreChunk getStoreChunk();", "public void map( Chunk bv ) { }", "int mo1684a(byte[] bArr, int i, int i2);", "private int getCol(int index) {\n return index & (chunkSize - 1);\n }", "int getBlockNumber();", "int getBlockNumber();", "public static long getChunks() {\n return chunks;\n }", "public Vector2i getChunkSize() {\n return new Vector2i(getChunkWidth(), getChunkHeight());\n }", "public void setChunkNumber(int chunkNumber) {\r\n\t\tthis.chunkNumber = chunkNumber;\r\n\t}", "private static void blockCoordsToChunkCoords(Vector3i pos) {\n pos.x >>= 4;\n pos.y >>= 4;\n pos.z >>= 4;\n }", "public void map( Chunk c ) { }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public boolean getChunking () {\n\treturn chunk;\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getStoreChunkLocation();", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "protected int nextInt(int p_75902_1_) {\n/* 135 */ int var2 = (int)((this.chunkSeed >> 24) % p_75902_1_);\n/* */ \n/* 137 */ if (var2 < 0)\n/* */ {\n/* 139 */ var2 += p_75902_1_;\n/* */ }\n/* */ \n/* 142 */ this.chunkSeed *= (this.chunkSeed * 6364136223846793005L + 1442695040888963407L);\n/* 143 */ this.chunkSeed += this.worldGenSeed;\n/* 144 */ return var2;\n/* */ }", "private int getIndex2(int val){\n return val/bucket;\n }", "@Override\r\n\tpublic int getIndexStep() {\n\t\t\r\n\t\treturn 2;\r\n\t}", "int getSplitIndex();", "public int getBlockSize()\n/* */ {\n/* 43 */ return this.blockSize;\n/* */ }", "int sampleOffset();", "public ChunkType getType();", "protected int arrayIndex(long windowIndex) {\n return (int) (windowIndex % length());\n }", "int getTotalBlockNum();", "void mo54417a(DownloadChunk downloadChunk);", "public int getChunkSize() {\n return chunkSize;\n }", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "public void map( Chunk cs[] ) { }", "int getBlockNumbers(int index);", "private int getImageBufferStartIndex(int trackNumber, FloppyDriveSide side) {\n return BYTES_PER_SECTOR * (SECTORS_PER_TRACK * (trackNumber * 2 + side.ordinal())\n + sectorIndex);\n }", "int getReadPosition(int index) {\n/* 170 */ return index - this.origPos + this.readerIndex;\n/* */ }", "private int getIndex(int val){\n return val%bucket;\n }", "@Test\n public void chunkPosShouldBePlayerPosDividedByChunkSizeWherePlayerAt1By1() {\n final int sideLengthOfBlock = 10;\n final int rowAmountInChunk = 11;\n\n MatcherAssert.assertThat(\n this.targetCompass(\n sideLengthOfBlock,\n rowAmountInChunk,\n new Point(1, 1)\n ).chunkPos(),\n CoreMatchers.equalTo(new Point(0, 0))\n );\n }", "private int key(int chunkX, int chunkY, int chunkZ) {\n if (chunkX >= 2048 || chunkX < 0 || chunkY >= 2048 || chunkY < 0 || chunkZ >= 4 || chunkZ < 0) {\n throw new IllegalArgumentException(\"ChunkX and ChunkY must range from 0-2047 inclusive (given x:\" + chunkX + \" and y: \" + chunkY + \"), and chunkZ must range from 0-3 inclusive (Given z: \" + chunkZ + \")\");\n }\n return (chunkZ << 30) | (chunkX << 15) | (chunkY);\n }", "protected int realIndex(int index) {\n return index & (buf.length -1);\n }", "private int getPmidIdx() {\n return this.colStartOffset + 2;\n }", "protected int populateBuffer()\n {\n interlock.beginReading();\n // System.out.println(\"populateBuffer: 2\");\n return byteBuffer.limit();\n }" ]
[ "0.785442", "0.785442", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.6741172", "0.6741172", "0.6663846", "0.66030824", "0.66030824", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6410397", "0.6400465", "0.6379588", "0.6373404", "0.6315273", "0.6189685", "0.6189685", "0.61568904", "0.61450183", "0.6116205", "0.600113", "0.592988", "0.5924839", "0.590925", "0.5907171", "0.5883504", "0.5868158", "0.58488417", "0.5830536", "0.5826126", "0.58231753", "0.57997054", "0.57831234", "0.5773982", "0.57738006", "0.5764445", "0.57457185", "0.574476", "0.5730925", "0.57199186", "0.5672394", "0.5635696", "0.56262887", "0.56262887", "0.56262887", "0.56262887", "0.5625486", "0.56026787", "0.55572665", "0.5555952", "0.55468774", "0.55468774", "0.5537924", "0.5523598", "0.55199176", "0.55137247", "0.55008006", "0.5499361", "0.5496236", "0.54885995", "0.54849046", "0.54820436", "0.54716635", "0.54495907", "0.544209", "0.5437883", "0.5429143", "0.5428823", "0.5428345", "0.54230964", "0.5416858", "0.54106504", "0.5405122", "0.54008263", "0.5391839", "0.5382947", "0.53820837", "0.5372417", "0.5371448", "0.53595173", "0.53501457", "0.53402644", "0.53377634", "0.53344655" ]
0.66893995
11
uint32 chunkIndex = 2;
public Builder setChunkIndex(int value) { chunkIndex_ = value; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "entities.Torrent.ChunkInfo getChunks(int index);", "int getNumOfChunks();", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "int getChunksCount();", "int getChunksCount();", "public int getHighestChunk() {\n return highestChunk_;\n }", "int getChunksLocationCount();", "public int getChunkWidth() {\n return 256;\n }", "public int currentChunkNum() {\n\t\treturn cp.chunk().getChunkNum();\n\t}", "int getChunkSize();", "public void nextTextureIndexX() {\n/* 245 */ this.particleTextureIndexX++;\n/* */ }", "List<DownloadChunk> mo54445j(int i);", "void sendChunkRequest(int chunkX, int chunkY);", "protected String _getChunkId(String id, int index) {\n\t\treturn id + \"[\" + index + \"]\";\n\t}", "public int getChunkHeight() {\n return 256;\n }", "public int getHighestChunk() {\n return highestChunk_;\n }", "String getChunkType();", "protected int getTextureIndex() {\n/* 83 */ return getData() & 0x7;\n/* */ }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public abstract int getNextBlock(int block) throws IOException;", "public int getInternalBlockLength()\r\n/* 40: */ {\r\n/* 41: 95 */ return 32;\r\n/* 42: */ }", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "boolean hasChunkId();", "void mo54426b(int i, List<DownloadChunk> list);", "@NotNull\n int getTrustedChunks();", "void mo54414a(int i, List<DownloadChunk> list);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "edu.usfca.cs.dfs.StorageMessages.StoreChunk getStoreChunk();", "public void map( Chunk bv ) { }", "int mo1684a(byte[] bArr, int i, int i2);", "private int getCol(int index) {\n return index & (chunkSize - 1);\n }", "int getBlockNumber();", "int getBlockNumber();", "public static long getChunks() {\n return chunks;\n }", "public Vector2i getChunkSize() {\n return new Vector2i(getChunkWidth(), getChunkHeight());\n }", "public void setChunkNumber(int chunkNumber) {\r\n\t\tthis.chunkNumber = chunkNumber;\r\n\t}", "private static void blockCoordsToChunkCoords(Vector3i pos) {\n pos.x >>= 4;\n pos.y >>= 4;\n pos.z >>= 4;\n }", "public void map( Chunk c ) { }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public boolean getChunking () {\n\treturn chunk;\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getStoreChunkLocation();", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "protected int nextInt(int p_75902_1_) {\n/* 135 */ int var2 = (int)((this.chunkSeed >> 24) % p_75902_1_);\n/* */ \n/* 137 */ if (var2 < 0)\n/* */ {\n/* 139 */ var2 += p_75902_1_;\n/* */ }\n/* */ \n/* 142 */ this.chunkSeed *= (this.chunkSeed * 6364136223846793005L + 1442695040888963407L);\n/* 143 */ this.chunkSeed += this.worldGenSeed;\n/* 144 */ return var2;\n/* */ }", "private int getIndex2(int val){\n return val/bucket;\n }", "@Override\r\n\tpublic int getIndexStep() {\n\t\t\r\n\t\treturn 2;\r\n\t}", "int getSplitIndex();", "public int getBlockSize()\n/* */ {\n/* 43 */ return this.blockSize;\n/* */ }", "int sampleOffset();", "public ChunkType getType();", "protected int arrayIndex(long windowIndex) {\n return (int) (windowIndex % length());\n }", "int getTotalBlockNum();", "void mo54417a(DownloadChunk downloadChunk);", "public int getChunkSize() {\n return chunkSize;\n }", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "public void map( Chunk cs[] ) { }", "int getBlockNumbers(int index);", "private int getImageBufferStartIndex(int trackNumber, FloppyDriveSide side) {\n return BYTES_PER_SECTOR * (SECTORS_PER_TRACK * (trackNumber * 2 + side.ordinal())\n + sectorIndex);\n }", "int getReadPosition(int index) {\n/* 170 */ return index - this.origPos + this.readerIndex;\n/* */ }", "private int getIndex(int val){\n return val%bucket;\n }", "@Test\n public void chunkPosShouldBePlayerPosDividedByChunkSizeWherePlayerAt1By1() {\n final int sideLengthOfBlock = 10;\n final int rowAmountInChunk = 11;\n\n MatcherAssert.assertThat(\n this.targetCompass(\n sideLengthOfBlock,\n rowAmountInChunk,\n new Point(1, 1)\n ).chunkPos(),\n CoreMatchers.equalTo(new Point(0, 0))\n );\n }", "private int key(int chunkX, int chunkY, int chunkZ) {\n if (chunkX >= 2048 || chunkX < 0 || chunkY >= 2048 || chunkY < 0 || chunkZ >= 4 || chunkZ < 0) {\n throw new IllegalArgumentException(\"ChunkX and ChunkY must range from 0-2047 inclusive (given x:\" + chunkX + \" and y: \" + chunkY + \"), and chunkZ must range from 0-3 inclusive (Given z: \" + chunkZ + \")\");\n }\n return (chunkZ << 30) | (chunkX << 15) | (chunkY);\n }", "protected int realIndex(int index) {\n return index & (buf.length -1);\n }", "private int getPmidIdx() {\n return this.colStartOffset + 2;\n }", "protected int populateBuffer()\n {\n interlock.beginReading();\n // System.out.println(\"populateBuffer: 2\");\n return byteBuffer.limit();\n }" ]
[ "0.785442", "0.785442", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.6741172", "0.6741172", "0.66893995", "0.66893995", "0.6663846", "0.66030824", "0.66030824", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6410397", "0.6400465", "0.6379588", "0.6373404", "0.6315273", "0.6189685", "0.6189685", "0.61568904", "0.61450183", "0.6116205", "0.600113", "0.592988", "0.5924839", "0.590925", "0.5907171", "0.5883504", "0.5868158", "0.58488417", "0.5830536", "0.5826126", "0.58231753", "0.57997054", "0.57831234", "0.5773982", "0.57738006", "0.5764445", "0.5730925", "0.57199186", "0.5672394", "0.5635696", "0.56262887", "0.56262887", "0.56262887", "0.56262887", "0.5625486", "0.56026787", "0.55572665", "0.5555952", "0.55468774", "0.55468774", "0.5537924", "0.5523598", "0.55199176", "0.55137247", "0.55008006", "0.5499361", "0.5496236", "0.54885995", "0.54849046", "0.54820436", "0.54716635", "0.54495907", "0.544209", "0.5437883", "0.5429143", "0.5428823", "0.5428345", "0.54230964", "0.5416858", "0.54106504", "0.5405122", "0.54008263", "0.5391839", "0.5382947", "0.53820837", "0.5372417", "0.5371448", "0.53595173", "0.53501457", "0.53402644", "0.53377634", "0.53344655" ]
0.57457185
53
uint32 chunkIndex = 2;
public Builder clearChunkIndex() { chunkIndex_ = 0; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getChunkIndex();", "int getChunkIndex();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "int getChunkId();", "public int getChunkNo() {\n return chunkNo;\n }", "public int getChunkNo() {\n return chunkNo;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "protected int getChunkInRegion() {\n\t\treturn (rnd.nextInt(structurePosRange) + rnd.nextInt(structurePosRange)) / 2;\n\t}", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "@java.lang.Override\n public int getChunkIndex() {\n return chunkIndex_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "public int getChunkId() {\n return chunkId_;\n }", "private int getChunk(byte [] buffer, int offset, String chunk) {\r\n\t\ttry {\r\n\t\t\tfor (;;) {\r\n\t\t\t\tint dataLenght = getInt(buffer, offset);\r\n\t\t\t\tif (compareBytes(buffer, offset+4, chunk)) {\r\n\t\t\t\t\treturn offset;\r\n\t\t\t\t} else {\r\n\t\t\t\t\toffset += 4 + 4 + dataLenght + 4;\r\n\t\t\t\t}\r\n\t\t\t}\r\n\t\t} catch (Exception e) {};\r\n\t\treturn -1;\r\n\t}", "entities.Torrent.ChunkInfo getChunks(int index);", "int getNumOfChunks();", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getChunksLocation(int index);", "private int chunk(long timestamp) {\n int chunkid;\n \n if (timestamp >= 0) {\n chunkid = (int) ((timestamp / chunklen) % chunkcount);\n } else {\n chunkid = chunkcount + (int) ((((timestamp + 1) / chunklen) % chunkcount) - 1);\n //chunkid = chunkcount - (int) ((- (timestamp + 1) / chunklen) % chunkcount);\n }\n \n return chunkid;\n }", "int getChunksCount();", "int getChunksCount();", "public int getHighestChunk() {\n return highestChunk_;\n }", "int getChunksLocationCount();", "public int getChunkWidth() {\n return 256;\n }", "public int currentChunkNum() {\n\t\treturn cp.chunk().getChunkNum();\n\t}", "int getChunkSize();", "public void nextTextureIndexX() {\n/* 245 */ this.particleTextureIndexX++;\n/* */ }", "List<DownloadChunk> mo54445j(int i);", "void sendChunkRequest(int chunkX, int chunkY);", "protected String _getChunkId(String id, int index) {\n\t\treturn id + \"[\" + index + \"]\";\n\t}", "public int getChunkHeight() {\n return 256;\n }", "public int getHighestChunk() {\n return highestChunk_;\n }", "String getChunkType();", "protected int getTextureIndex() {\n/* 83 */ return getData() & 0x7;\n/* */ }", "public int getChunkCount () {\n return (this.getTagCount()>>BITS_TO_SHIFT_FOR_CHUNK) + 1;\n }", "public abstract int getNextBlock(int block) throws IOException;", "public int getInternalBlockLength()\r\n/* 40: */ {\r\n/* 41: 95 */ return 32;\r\n/* 42: */ }", "private static boolean parseChunk(final FileChannel fc,final long[] offset,final int depth) throws IOException {\n\t Log.d(TAG, \"entering parseChunk \"+ offset[0] +\"/\"+ depth);\n\n\t long data_offset = offset[0];\n\n long chunk_size = Util.readUInt(fc, data_offset); \n int chunk_type = Util.readInt(fc, data_offset+4);\n\n Log.v(TAG, chunk_type + \" \" + chunk_size);\n char sChunk[] = new char[4];\n Util.MakeFourCCString(chunk_type, sChunk);\n Log.v(TAG, String.format(\"chunk %s\", String.valueOf(sChunk)));\n\n data_offset += 8;\n // long chunk_data_size = offset[0] + chunk_size - data_offset;\n\n if (chunk_size == 1) {\n\n chunk_size = Util.readLong(fc, data_offset);\n\n data_offset += 8;\n\n if (chunk_size < 16) {\n Log.e(TAG,\" The smallest valid chunk is 16 bytes long in this case.\");\n return false;\n }\n\n } else if (chunk_size < 8) {\n Log.e(TAG,\"The smallest valid chunk is 8 bytes long.\");\n return false;\n }\n\n Log.v(TAG, String.format(\"parsing chunk %s at depth %d\",\n String.valueOf(sChunk), depth));\n\n if(chunk_type == Util.FOURCC('m', 'o', 'o', 'v') || chunk_type == Util.FOURCC('u', 'd', 't', 'a')) {\n Log.d(TAG, String.valueOf(sChunk));\n\n long stop_offset = offset[0] + chunk_size;\n offset[0] = data_offset;\n while (offset[0] < stop_offset) {\n boolean err = parseChunk(fc,offset, depth + 1);\n if (!err) {\n return err;\n }\n }\n\n if (offset[0] != stop_offset) {\n return false;\n }\n\n if (chunk_type == Util.FOURCC('m', 'o', 'o', 'v') ) {\n return true;\n }\n }\n else if(chunk_type == Util.FOURCC('h', 't', 'c', 'b')) {\n Log.d(TAG,\"Found Htc MetaData\");\n sHtcTableOffset = data_offset;\n Log.d(TAG,\"sHtcTableOffset = \" + sHtcTableOffset );\n parseHtcMetaData(fc,data_offset,chunk_size);\n Log.d(TAG,\"Parse Htc MetaData done\");\n offset[0] += chunk_size;\n } else if (chunk_type == Util.FOURCC('_', 'h', 't', 'c')\n || chunk_type == Util.FOURCC('d', 't', 'a', 'h')) {\n Log.d(TAG, \"Found HTC box\");\n offset[0] += 8;\n parseChunk(fc, offset, depth + 1);\n } else {\n offset[0] += chunk_size;\n }\n return true;\n }", "public int getMaxSpawnedInChunk()\n {\n return 1;\n }", "public boolean isNewChunk() {\n/* 26 */ return this.newChunk;\n/* */ }", "public Builder setChunkIndex(int value) {\n\n chunkIndex_ = value;\n onChanged();\n return this;\n }", "public Builder setChunkIndex(int value) {\n\n chunkIndex_ = value;\n onChanged();\n return this;\n }", "boolean hasChunkId();", "void mo54426b(int i, List<DownloadChunk> list);", "@NotNull\n int getTrustedChunks();", "void mo54414a(int i, List<DownloadChunk> list);", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "long getChunkSize();", "edu.usfca.cs.dfs.StorageMessages.StoreChunk getStoreChunk();", "public void map( Chunk bv ) { }", "int mo1684a(byte[] bArr, int i, int i2);", "private int getCol(int index) {\n return index & (chunkSize - 1);\n }", "int getBlockNumber();", "int getBlockNumber();", "public static long getChunks() {\n return chunks;\n }", "public Vector2i getChunkSize() {\n return new Vector2i(getChunkWidth(), getChunkHeight());\n }", "public void setChunkNumber(int chunkNumber) {\r\n\t\tthis.chunkNumber = chunkNumber;\r\n\t}", "private static void blockCoordsToChunkCoords(Vector3i pos) {\n pos.x >>= 4;\n pos.y >>= 4;\n pos.z >>= 4;\n }", "public void map( Chunk c ) { }", "public int getNumOfChunks() {\n return numOfChunks_;\n }", "@Test\n public void testChunkType() {\n final int[] count = new int[255];\n final SctpChunk.Type[] types = SctpChunk.Type.values();\n for (int i = 0; i < types.length; ++i) {\n count[types[i].getType()] = count[types[i].getType()] + 1;\n }\n\n for (int i = 0; i < count.length; ++i) {\n assertThat(\"Found multiple type definitions for Chunk Type \" + i, count[i] < 2, is(true));\n }\n\n }", "public boolean getChunking () {\n\treturn chunk;\n }", "edu.usfca.cs.dfs.StorageMessages.StoreChunkLocation getStoreChunkLocation();", "private void generateNextChunk() {\n \n chunkNumber++;\n \n // generate a chunk filled with content\n List<Object> list = chunkFactory.generateChunk(chunkNumber);\n Vector3f newChunkPosition =\n new Vector3f(nextChunkX, 0f, 0f);\n nextChunkX += P.chunkLength;\n\n for (Object object : list) {\n if (object instanceof Spatial) {\n Spatial spatial = (Spatial) object;\n addToLevel(spatial, spatial.getLocalTranslation().add(newChunkPosition));\n } else if (object instanceof SpotLight) {\n SpotLight light = (SpotLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition));\n } else if (object instanceof PointLight) {\n PointLight light = (PointLight) object;\n addToLevel(light, light.getPosition().add(newChunkPosition)); \n }\n }\n\n }", "protected int nextInt(int p_75902_1_) {\n/* 135 */ int var2 = (int)((this.chunkSeed >> 24) % p_75902_1_);\n/* */ \n/* 137 */ if (var2 < 0)\n/* */ {\n/* 139 */ var2 += p_75902_1_;\n/* */ }\n/* */ \n/* 142 */ this.chunkSeed *= (this.chunkSeed * 6364136223846793005L + 1442695040888963407L);\n/* 143 */ this.chunkSeed += this.worldGenSeed;\n/* 144 */ return var2;\n/* */ }", "private int getIndex2(int val){\n return val/bucket;\n }", "@Override\r\n\tpublic int getIndexStep() {\n\t\t\r\n\t\treturn 2;\r\n\t}", "int getSplitIndex();", "public int getBlockSize()\n/* */ {\n/* 43 */ return this.blockSize;\n/* */ }", "int sampleOffset();", "public ChunkType getType();", "protected int arrayIndex(long windowIndex) {\n return (int) (windowIndex % length());\n }", "int getTotalBlockNum();", "void mo54417a(DownloadChunk downloadChunk);", "public int getChunkSize() {\n return chunkSize;\n }", "public static void splitFile() throws IOException{\n\t\tPath currentRelativePath = Paths.get(\"\");\n\t\tFile file = new File(currentRelativePath.toAbsolutePath().toString()+\"/\"+fileName);\n\n\t\t//fileChunks are of size windowSize\n\t\tint num = fileSize; \n\t\tint lastByteRead = 0;\n\t\tint start =0;\n\t\tint i= 0; //where we are in bitfield map\n\t\tbyte[] fileChunkArray = new byte[windowSize];\n\t\t//read in the file\n\t\ttry{\n\t\t\tFileInputStream fileInputStream = new FileInputStream(file);\n\t\t\twhile(num > 0){\n\t\t\t\tif (num <= 5){\n\t\t\t\t\twindowSize = num;\n\t\t\t\t}\n\t\t\t\t// byte[] fileChunkArray = new byte[windowSize];\n\t\t\t\t\n\t\t\t\tlastByteRead = fileInputStream.read(fileChunkArray,0,windowSize);\n\t\t\t\t\n\t\t\t\t// start = start +windowSize;\n\t\t\t\t\n\t\t\t\t// String s1 = new String(fileChunkArray);\n\t\t\t\tSystem.out.print(\"the chunkarray length is :\" + fileChunkArray.length);\n\t\t\t\tSystem.out.print(\"the lastbyte read is :\"+ lastByteRead);\n\t\t\t\t// System.out.print(\"the fileChunk array is :\"+ s1);\n\t\t\t\tbitfieldMap.put(lastByteRead,fileChunkArray);\n\t\t\t\ti++;\n\t\t\t\tdynamicName = fileName+ i;\n\t\t\t\tworkingDirectory = System.getProperty(\"user.dir\");\n\t\t\t\tabsoluteFilePath = workingDirectory + File.separator + dynamicName;\n\t\t\t\tnum = num - windowSize; \n\t\t\t\tFileOutputStream newFile = new FileOutputStream(absoluteFilePath);\n\t\t\t\tnewFile.write(fileChunkArray);\n\t\t\t\tnewFile.flush();\n\t\t\t\tnewFile.close();\n\n\t\t\t}\n\t\t\tfileInputStream.close();\t\n\t\t}catch(IOException ioe){\n\t\t\tSystem.out.println(\"Could not split file: \" + ioe);\n\t\t}\n\t}", "public void map( Chunk cs[] ) { }", "int getBlockNumbers(int index);", "private int getImageBufferStartIndex(int trackNumber, FloppyDriveSide side) {\n return BYTES_PER_SECTOR * (SECTORS_PER_TRACK * (trackNumber * 2 + side.ordinal())\n + sectorIndex);\n }", "int getReadPosition(int index) {\n/* 170 */ return index - this.origPos + this.readerIndex;\n/* */ }", "private int getIndex(int val){\n return val%bucket;\n }", "@Test\n public void chunkPosShouldBePlayerPosDividedByChunkSizeWherePlayerAt1By1() {\n final int sideLengthOfBlock = 10;\n final int rowAmountInChunk = 11;\n\n MatcherAssert.assertThat(\n this.targetCompass(\n sideLengthOfBlock,\n rowAmountInChunk,\n new Point(1, 1)\n ).chunkPos(),\n CoreMatchers.equalTo(new Point(0, 0))\n );\n }", "private int key(int chunkX, int chunkY, int chunkZ) {\n if (chunkX >= 2048 || chunkX < 0 || chunkY >= 2048 || chunkY < 0 || chunkZ >= 4 || chunkZ < 0) {\n throw new IllegalArgumentException(\"ChunkX and ChunkY must range from 0-2047 inclusive (given x:\" + chunkX + \" and y: \" + chunkY + \"), and chunkZ must range from 0-3 inclusive (Given z: \" + chunkZ + \")\");\n }\n return (chunkZ << 30) | (chunkX << 15) | (chunkY);\n }", "protected int realIndex(int index) {\n return index & (buf.length -1);\n }", "private int getPmidIdx() {\n return this.colStartOffset + 2;\n }", "protected int populateBuffer()\n {\n interlock.beginReading();\n // System.out.println(\"populateBuffer: 2\");\n return byteBuffer.limit();\n }" ]
[ "0.785442", "0.785442", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.73773885", "0.6741172", "0.6741172", "0.66893995", "0.66893995", "0.6663846", "0.66030824", "0.66030824", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.65638685", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6424548", "0.6410397", "0.6400465", "0.6379588", "0.6373404", "0.6315273", "0.6189685", "0.6189685", "0.61568904", "0.61450183", "0.6116205", "0.600113", "0.592988", "0.5924839", "0.590925", "0.5907171", "0.5883504", "0.5868158", "0.58488417", "0.5830536", "0.5826126", "0.58231753", "0.57997054", "0.57831234", "0.5773982", "0.57738006", "0.5764445", "0.57457185", "0.574476", "0.5730925", "0.57199186", "0.5672394", "0.5635696", "0.56262887", "0.56262887", "0.56262887", "0.56262887", "0.5625486", "0.56026787", "0.55572665", "0.5555952", "0.55468774", "0.55468774", "0.5537924", "0.5523598", "0.55199176", "0.55137247", "0.55008006", "0.5499361", "0.5496236", "0.54885995", "0.54849046", "0.54820436", "0.54716635", "0.54495907", "0.544209", "0.5437883", "0.5429143", "0.5428823", "0.5428345", "0.54230964", "0.5416858", "0.54106504", "0.5405122", "0.54008263", "0.5391839", "0.5382947", "0.53820837", "0.5372417", "0.5371448", "0.53595173", "0.53501457", "0.53402644", "0.53377634", "0.53344655" ]
0.0
-1
.Status status = 3;
@java.lang.Override public int getStatusValue() { return status_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
.Status status = 3;
public Builder setStatusValue(int value) { status_ = value; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
.Status status = 3;
@java.lang.Override public entities.Torrent.Status getStatus() { @SuppressWarnings("deprecation") entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_); return result == null ? entities.Torrent.Status.UNRECOGNIZED : result; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
.Status status = 3;
public Builder setStatus(entities.Torrent.Status value) { if (value == null) { throw new NullPointerException(); } status_ = value.getNumber(); onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
.Status status = 3;
public Builder clearStatus() { status_ = 0; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "void mo9948a(Status cVar);", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "void setStatus(String status);", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus( Short status ) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "void setStatus(java.lang.String status);", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(int value) {\n this.status = value;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.7411056", "0.7367511", "0.73645175", "0.73291516", "0.73291516", "0.7287494", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.726566", "0.7256919", "0.7255675", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.72538924", "0.7253363", "0.7253363", "0.72526133", "0.72416043", "0.7238751", "0.7216158", "0.721198", "0.72090006", "0.72090006", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7192751", "0.7188882", "0.7180113", "0.71728295", "0.7164907", "0.7157636", "0.71494794", "0.7146996", "0.7146996", "0.7141134", "0.7137717", "0.7137717", "0.71375126", "0.71364444", "0.71364444", "0.7129469", "0.7128966", "0.7123521", "0.7109237", "0.7109237", "0.7107745", "0.7083731", "0.70836896", "0.70809793", "0.7079029", "0.70623165", "0.7056048", "0.70523334", "0.7051204", "0.70490533", "0.70483994", "0.70483994", "0.7041842", "0.7041842", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207", "0.7033207" ]
0.0
-1
string errorMessage = 4;
public java.lang.String getErrorMessage() { java.lang.Object ref = errorMessage_; if (!(ref instanceof java.lang.String)) { com.google.protobuf.ByteString bs = (com.google.protobuf.ByteString) ref; java.lang.String s = bs.toStringUtf8(); errorMessage_ = s; return s; } else { return (java.lang.String) ref; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.58869445
78
string errorMessage = 4;
public com.google.protobuf.ByteString getErrorMessageBytes() { java.lang.Object ref = errorMessage_; if (ref instanceof String) { com.google.protobuf.ByteString b = com.google.protobuf.ByteString.copyFromUtf8( (java.lang.String) ref); errorMessage_ = b; return b; } else { return (com.google.protobuf.ByteString) ref; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.5886582", "0.5886582", "0.5886582", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.0
-1
string errorMessage = 4;
public Builder setErrorMessage( java.lang.String value) { if (value == null) { throw new NullPointerException(); } errorMessage_ = value; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.5886582", "0.5886582", "0.5886582", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.0
-1
string errorMessage = 4;
public Builder clearErrorMessage() { errorMessage_ = getDefaultInstance().getErrorMessage(); onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.5886582", "0.5886582", "0.5886582", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.0
-1
string errorMessage = 4;
public Builder setErrorMessageBytes( com.google.protobuf.ByteString value) { if (value == null) { throw new NullPointerException(); } checkByteStringIsUtf8(value); errorMessage_ = value; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getErrorsString();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public void error(String string) {\n\t\t\n\t}", "public String getError() {\n\treturn mistake;\n }", "String getMessage();", "String getMessage();", "String getMessage();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "String Message ();", "public String errorMessage() {\n return errorMessage;\n }", "public String getErrorCode();", "String getErrorMessage(E input);", "int getErrorCode();", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "public String getErrorMessage()\n {\n return errorMessage;\n }", "void SemErr(String str);", "public String getError(String code) {\r\n\t\tswitch (code) {\r\n\t\tcase \"01\":\r\n\t\t\treturn Const.MSG_LOGIN;\r\n\t\tcase \"02\":\r\n\t\t\treturn Const.MSG_NO_FREE_DEVICES;\r\n\t\tcase \"03\":\r\n\t\t\treturn Const.MSG_SEND_EMAIL_TO;\r\n\t\tcase \"11\":\r\n\t\t\treturn \"Не указаны адрес электронной почты или тело сообщения.\";\r\n\t\t\t// case \"14\":\r\n\t\t\t// return \"Проверьте адрес электронной почты.\\n\"\r\n\t\t\t// + \"На него не удалось отправить подтверждающее письмо.\";\r\n\t\tdefault:\r\n\t\t\treturn activationRequest ? Const.MSG_SEND_EMAIL_TO\r\n\t\t\t\t\t: Const.MSG_SEND_EMAIL_TO_MSG;\r\n\t\t}\r\n\t}", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public String getError() {\n return errMsg;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "private static int getErrorLine(String errmsg){\n\t\treturn Integer.parseInt(errmsg.substring(0,errmsg.indexOf(\":\")).substring(errmsg.substring(0,errmsg.indexOf(\":\")).lastIndexOf(\" \")+1));\n\t}", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public int getError() {\n return error;\n }", "public int error() {\n return this.error;\n }", "void showError(@StringRes int errorMessage);", "void showError(String errorMessage);", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "public String getParseErrorMessage();", "@Override\n\tpublic String getMessage()\n\t{\n\t\treturn errMessage;\n\t}", "public String errorMessage() {\n return this.errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "String getFailureMessage();", "public static String getLastLrcErrorMsg() {\n String str = new String(mLrcErrorMsg);\n return str;\n }" ]
[ "0.7475414", "0.69459975", "0.69459975", "0.68936586", "0.68223494", "0.68223494", "0.68223494", "0.6813258", "0.672401", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.669224", "0.6624547", "0.65803754", "0.656268", "0.6561109", "0.6552149", "0.65018326", "0.6489057", "0.645184", "0.6403019", "0.6332465", "0.63124645", "0.63124645", "0.63124645", "0.63114697", "0.6278728", "0.6204877", "0.6187614", "0.6167885", "0.61640996", "0.61180544", "0.61154515", "0.61122483", "0.61060935", "0.60728073", "0.60667354", "0.6027591", "0.6026474", "0.6011854", "0.5986385", "0.5980889", "0.59754777", "0.59430844", "0.59407336", "0.5939085", "0.59310424", "0.59239143", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.5918069", "0.589988", "0.58985275", "0.58875334", "0.58874065", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.58869445", "0.5886582", "0.5886582", "0.5886582", "0.58862025", "0.588058", "0.58804154", "0.58763623", "0.5872998", "0.5869356", "0.58543724", "0.5851408", "0.58409274", "0.5826933", "0.5823647", "0.582103", "0.5820706" ]
0.0
-1
.NodeId node = 1;
boolean hasNode();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
entities.Torrent.NodeId getNode();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.66503185
8
.NodeId node = 1;
entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.5917212
57
.Status status = 2;
int getStatusValue();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
.Status status = 2;
entities.Torrent.Status getStatus();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
string errorMessage = 3;
java.lang.String getErrorMessage();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59142876", "0.59142876", "0.59142876", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.67127615
19
string errorMessage = 3;
com.google.protobuf.ByteString getErrorMessageBytes();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59142876", "0.59142876", "0.59142876", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.0
-1
repeated .FileInfo files = 4;
java.util.List<entities.Torrent.FileInfo> getFilesList();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.0
-1
repeated .FileInfo files = 4;
entities.Torrent.FileInfo getFiles(int index);
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.6177881
2
repeated .FileInfo files = 4;
int getFilesCount();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.58970237
8
repeated .FileInfo files = 4;
java.util.List<? extends entities.Torrent.FileInfoOrBuilder> getFilesOrBuilderList();
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.0
-1
repeated .FileInfo files = 4;
entities.Torrent.FileInfoOrBuilder getFilesOrBuilder( int index);
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.5744839
15
Use NodeSearchResult.newBuilder() to construct.
private NodeSearchResult(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) { super(builder); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "entities.Torrent.NodeSearchResultOrBuilder getResultsOrBuilder(\n int index);", "public entities.Torrent.NodeSearchResult.Builder addResultsBuilder() {\n return getResultsFieldBuilder().addBuilder(\n entities.Torrent.NodeSearchResult.getDefaultInstance());\n }", "entities.Torrent.NodeSearchResult getResults(int index);", "public Builder addResults(entities.Torrent.NodeSearchResult value) {\n if (resultsBuilder_ == null) {\n if (value == null) {\n throw new NullPointerException();\n }\n ensureResultsIsMutable();\n results_.add(value);\n onChanged();\n } else {\n resultsBuilder_.addMessage(value);\n }\n return this;\n }", "public entities.Torrent.NodeSearchResult.Builder addResultsBuilder(\n int index) {\n return getResultsFieldBuilder().addBuilder(\n index, entities.Torrent.NodeSearchResult.getDefaultInstance());\n }", "public Builder addAllResults(\n java.lang.Iterable<? extends entities.Torrent.NodeSearchResult> values) {\n if (resultsBuilder_ == null) {\n ensureResultsIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, results_);\n onChanged();\n } else {\n resultsBuilder_.addAllMessages(values);\n }\n return this;\n }", "public ResultMap<BaseNode> findNodes(ObjectNode query, String searchTerm, ObjectNode traverse, Pagination pagination);", "java.util.List<? extends entities.Torrent.NodeSearchResultOrBuilder>\n getResultsOrBuilderList();", "public ResultMap<BaseNode> findNodes(ObjectNode query, String searchTerm, ObjectNode traverse);", "public entities.Torrent.NodeSearchResult.Builder getResultsBuilder(\n int index) {\n return getResultsFieldBuilder().getBuilder(index);\n }", "java.util.List<entities.Torrent.NodeSearchResult>\n getResultsList();", "public entities.Torrent.NodeSearchResultOrBuilder getResultsOrBuilder(\n int index) {\n if (resultsBuilder_ == null) {\n return results_.get(index); } else {\n return resultsBuilder_.getMessageOrBuilder(index);\n }\n }", "@java.lang.Override\n public entities.Torrent.NodeSearchResultOrBuilder getResultsOrBuilder(\n int index) {\n return results_.get(index);\n }", "public Builder setResults(\n int index, entities.Torrent.NodeSearchResult value) {\n if (resultsBuilder_ == null) {\n if (value == null) {\n throw new NullPointerException();\n }\n ensureResultsIsMutable();\n results_.set(index, value);\n onChanged();\n } else {\n resultsBuilder_.setMessage(index, value);\n }\n return this;\n }", "TSearchResults createSearchResults(TSearchQuery searchQuery);", "public Builder addResults(\n int index, entities.Torrent.NodeSearchResult value) {\n if (resultsBuilder_ == null) {\n if (value == null) {\n throw new NullPointerException();\n }\n ensureResultsIsMutable();\n results_.add(index, value);\n onChanged();\n } else {\n resultsBuilder_.addMessage(index, value);\n }\n return this;\n }", "public ListSearchResults()\n {\n logEnter(LOG_TAG, \"<init>\");\n\n entryMap = new HashMap<String,SearchResultEntry>(0);\n entries = new LinkedList<SearchResultEntry>();\n instance = null;\n }", "@java.lang.Override\n public java.util.List<? extends entities.Torrent.NodeSearchResultOrBuilder>\n getResultsOrBuilderList() {\n return results_;\n }", "public Builder addResults(\n entities.Torrent.NodeSearchResult.Builder builderForValue) {\n if (resultsBuilder_ == null) {\n ensureResultsIsMutable();\n results_.add(builderForValue.build());\n onChanged();\n } else {\n resultsBuilder_.addMessage(builderForValue.build());\n }\n return this;\n }", "public java.util.List<entities.Torrent.NodeSearchResult> getResultsList() {\n if (resultsBuilder_ == null) {\n return java.util.Collections.unmodifiableList(results_);\n } else {\n return resultsBuilder_.getMessageList();\n }\n }", "public java.util.List<? extends entities.Torrent.NodeSearchResultOrBuilder>\n getResultsOrBuilderList() {\n if (resultsBuilder_ != null) {\n return resultsBuilder_.getMessageOrBuilderList();\n } else {\n return java.util.Collections.unmodifiableList(results_);\n }\n }", "public RemoteNode(ServiceMetadata serviceMetadata,\n\t\t\t EndpointReferenceType endpoint,\n\t\t\t AvailableSearchTerms availableSearchTerms,\n\t\t\t UsAvailableSearchTerms usAvailableSearchTerms) {\n\t\tsuper(false,\n\t\t\t serviceMetadata.getHostingResearchCenter().getResearchCenter().getDisplayName(),\n\t\t\t endpoint.getAddress().toString());\n\t\tthis.serviceMetadata = serviceMetadata;\n\t\tthis.endpointReferenceType = endpoint;\n\t\tthis.availableSearchTerms = availableSearchTerms;\n\t\tthis.usAvailableSearchTerms = usAvailableSearchTerms;\n\t\tcreationTime = new Date();\n\t}", "@java.lang.Override\n public java.util.List<entities.Torrent.NodeSearchResult> getResultsList() {\n return results_;\n }", "List<SearchResult> search(SearchQuery searchQuery);", "entities.Torrent.SearchResponseOrBuilder getSearchResponseOrBuilder();", "public entities.Torrent.NodeSearchResult getResults(int index) {\n if (resultsBuilder_ == null) {\n return results_.get(index);\n } else {\n return resultsBuilder_.getMessage(index);\n }\n }", "@java.lang.Override\n public entities.Torrent.NodeSearchResult getResults(int index) {\n return results_.get(index);\n }", "private static SearchResponse createSearchResponse() {\n long tookInMillis = randomNonNegativeLong();\n int totalShards = randomIntBetween(1, Integer.MAX_VALUE);\n int successfulShards = randomIntBetween(0, totalShards);\n int skippedShards = randomIntBetween(0, totalShards);\n InternalSearchResponse internalSearchResponse = InternalSearchResponse.empty();\n\n return new SearchResponse(\n internalSearchResponse,\n null,\n totalShards,\n successfulShards,\n skippedShards,\n tookInMillis,\n ShardSearchFailure.EMPTY_ARRAY,\n SearchResponse.Clusters.EMPTY\n );\n }", "private SearchResponse(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) {\n super(builder);\n }", "XResultSet() {\n this.nodeRefs = new LinkedList<>();\n this.numberFound = 0;\n }", "public AbstractElement(final Result result) {\n results = singleton(result, Result.class);\n }", "public Results(Node source) {\n\t\tinorder(source);\n\t}", "private Search() {}", "public SearchResponse(String from, String to, UUID uuid, Set<Entry> results) {\r\n super(from, to, new JSONObject()\r\n .put(\"type\", MessageType.SEARCH_RESPONSE.name())\r\n .put(\"status\", \"ok\")\r\n .put(\"id\", uuid.toString())\r\n .put(\"results\", new JSONArray()));\r\n for(Entry result : results)\r\n getPayload().getJSONArray(\"results\").put(result.serialize());\r\n }", "public SearchTreeNode()\n\t{\n\t\tthis.word = \"\";\n\t\tthis.children = new HashSet<>();\n\t}", "public Search() {\n this.timestamp = System.currentTimeMillis();\n }", "protected void addingNode( SearchNode n ) { }", "public List<NodeInfo> getStoredNodes() {\n List<NodeInfo> nodes = new ArrayList<>();\n\n SearchResponse response = client.prepareSearch(\"k8s_*\").setTypes(\"node\").setSize(10000).get();\n\n SearchHit[] hits = response.getHits().getHits();\n log.info(String.format(\"The length of node search hits is [%d]\", hits.length));\n\n ObjectMapper mapper = new ObjectMapper();\n try {\n for (SearchHit hit : hits) {\n// log.info(hit.getSourceAsString());\n NodeInfo node = mapper.readValue(hit.getSourceAsString(), NodeInfo.class);\n nodes.add(node);\n }\n } catch (Exception e) {\n e.printStackTrace();\n }\n return nodes;\n }", "protected SearchNode<T> getSearchNode( Node<T> node ) {\n\t\treturn node == null ? null : searchNodes.get( node.getNodeId() );\n\t}", "entities.Torrent.SearchResponse getSearchResponse();", "entities.Torrent.LocalSearchResponse getLocalSearchResponse();", "public interface SearchResult {\n\t/**\n\t * Returns the meta data of this entity associated with the search result.\n\t * \n\t * @return\tThe meta data\n\t */\n\tMetadata getMetaData();\n\t\n\t/**\n\t * Returns the identifier of this entity associated with the search result.\n\t * \n\t * @return\tThe identifier\n\t */\n\tString getHash();\n\t\n\t/**\n\t * Returns the hash algorithm used for hashing the content.\n\t * \n\t * @return The hash algorithm\n\t */\n\tString getHashAlgorithm();\n}", "SearchResponse search(SearchRequest searchRequest) throws IOException;", "public NodeInfo() {\n }", "protected List<SearchResultElement> getResultElementsFromNodes(\n IProgressMonitor monitor, INodePO[] reuse) {\n final List<SearchResultElement> reuseLoc =\n new ArrayList<SearchResultElement>(reuse.length);\n\n for (INodePO node : reuse) {\n INodePO parent = node.getSpecAncestor();\n if (parent == null) {\n parent = node.getParentNode();\n }\n if (parent != null) {\n Long id = node.getId();\n String nodeName = GeneralLabelProvider.getTextImpl(node);\n reuseLoc.add(new SearchResultElement<Long>(NLS.bind(\n Messages.SearchResultPageElementLabel, new Object[] {\n parent.getName(), nodeName }), id,\n GeneralLabelProvider.getImageImpl(node),\n new NodeSearchResultElementAction(), node\n .getComment()));\n }\n monitor.worked(1);\n }\n return reuseLoc;\n }", "private LocalSearchResponse(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) {\n super(builder);\n }", "public SearchResults() {\n\t\tPageFactory.initElements(driver, this);\n\t}", "public search() {\n }", "SearchResult<TimelineMeta> search(SearchQuery searchQuery);", "private SearchRequest(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) {\n super(builder);\n }", "public Builder addResults(\n int index, entities.Torrent.NodeSearchResult.Builder builderForValue) {\n if (resultsBuilder_ == null) {\n ensureResultsIsMutable();\n results_.add(index, builderForValue.build());\n onChanged();\n } else {\n resultsBuilder_.addMessage(index, builderForValue.build());\n }\n return this;\n }", "public void discover(Node n) {}", "public static Result fromXMLElement(String query, XMLElement resultElement){\n\t\tResult result = new Result();\n\t\t\n\t\t/* Set query. */\n\t\tresult.query = query;\n\t\t\n\t\t/* Set suggestion. */\n\t\tif(resultElement.hasChild(\"did-you-mean\")){\n\t\t\tresult.suggestion = resultElement.getChildText(\"did-you-mean\");\n\t\t}\n\t\t\n\t\t/* Set result quantities.*/\n\t\tif(resultElement.hasChild(\"total-artists\") &&\n\t\t\tresultElement.hasChild(\"total-albums\") &&\n\t\t\tresultElement.hasChild(\"total-tracks\")){\n\t\t\tresult.totalArtists = Integer.parseInt(resultElement.getChildText(\"total-artists\"));\n\t\t\tresult.totalAlbums = Integer.parseInt(resultElement.getChildText(\"total-albums\"));\n\t\t\tresult.totalTracks = Integer.parseInt(resultElement.getChildText(\"total-tracks\"));\n\t\t}\n\t\t\n\t\t/* Get artists. */\n\t\tif(resultElement.hasChild(\"artists\")){\n\t\t\tfor(XMLElement artistElement : resultElement.getChild(\"artists\").getChildren()){\n\t\t\t\tresult.artists.add(Artist.fromXMLElement(artistElement));\n\t\t\t}\n\t\t}\n\t\t\n\t\t/* Get albums. */\n\t\tif(resultElement.hasChild(\"albums\")){\n\t\t\tfor(XMLElement albumElement : resultElement.getChild(\"albums\").getChildren()){\n\t\t\t\tresult.albums.add(Album.fromXMLElement(albumElement));\n\t\t\t}\n\t\t}\n\t\t\n\t\t/* Get tracks. */\n\t\tif(resultElement.hasChild(\"tracks\")){\n\t\t\tfor(XMLElement trackElement : resultElement.getChild(\"tracks\").getChildren()){\n\t\t\t\tresult.tracks.add(Track.fromXMLElement(trackElement));\n\t\t\t}\n\t\t}\n\t\t\n\t\t/* Return result. */\n\t\treturn result;\n\t}", "public interface SearchResult {\n\n\t/**\n\t * Gets the rank of the result fetched.\n\t * \n\t * @return The rank of the result (starting with 1).\n\t */\n\tpublic int getRank(); \n\n /**\n * Gets the title of the result fetched.\n * \n * @return The title of result.\n */\n public String getTitle();\n \n /**\n * Gets the URL that can be used for accessing the document. The URL is specifically required\n * when fetching the content.\n * \n * @return The URL of the result.\n * @throws SearchResultException The URL might be malformed.\n */\n public URL getURL() throws SearchResultException; \n \n /**\n * Get a short summary of the document. This summary is usually provided by the SearchEngine\n * and should therefore not resolve in an exception.\n * \n * @return The summary of the result.\n */\n public String getSummary();\n \n /**\n * Retrieves the HTML content of a result. For this, a HTTP connection has to be created that\n * can result in connection exceptions. These exceptions are packed in abstract \n * \"SearchResultException\". The content will be plain text.\n * \n * @return The content document related to a result\n * @throws SearchResultException The retrieval of the document might fail.\n */\n public String getContent() throws SearchResultException;\n \n /**\n * Retrieves all links of a result document. For this the content document is searched for all\n * links and forms. Their URLs are extracted, cleaned, and returned as a list. \n * \n * @return List of URLs of documents linked to by this document\n * @throws SearchResultException The document might not be available and retrieval might fail.\n */\n public Set<String> getLinks() throws SearchResultException;\n}", "public Builder setResults(\n int index, entities.Torrent.NodeSearchResult.Builder builderForValue) {\n if (resultsBuilder_ == null) {\n ensureResultsIsMutable();\n results_.set(index, builderForValue.build());\n onChanged();\n } else {\n resultsBuilder_.setMessage(index, builderForValue.build());\n }\n return this;\n }", "entities.Torrent.SearchRequestOrBuilder getSearchRequestOrBuilder();", "@Override\n\tpublic NodeIterator search(String queryString) throws Exception {\n\t\treturn null;\n\t}", "public Node() {\n this.nodeMap = new HashMap<>();\n }", "public static QueryResult fromIndexerResult(Document document) {\n return new QueryResult.Builder()\n .content(document.get(LuceneFieldConstants.CONTENT.getText()))\n .filename(document.get(LuceneFieldConstants.FILE_NAME.getText()))\n .build();\n\n }", "public SearchResponse<T, P> build(Pageable searchRequest, QueryResponse queryResponse) {\n // Create response\n SearchResponse<T, P> searchResponse = new SearchResponse<T, P>(searchRequest);\n searchResponse.setCount(queryResponse.getResults().getNumFound());\n searchResponse.setLimit(queryResponse.getResults().size());\n // The results and facets are copied into the response\n final List<ST> resultsST = queryResponse.getBeans(annotatedClass);\n // convert types\n final List<T> results = Lists.newArrayList();\n for (ST x : resultsST) {\n results.add(x);\n }\n searchResponse.setResults(results);\n searchResponse.setFacets(getFacetsFromResponse(queryResponse));\n setHighlightedFields(searchResponse, queryResponse);\n if(queryResponse.getSpellCheckResponse() != null){\n searchResponse.setSpellCheckResponse(SpellCheckResponseBuilder.build(queryResponse.getSpellCheckResponse()));\n }\n return searchResponse;\n }", "protected DefaultMutableTreeNode createResultTree(Cluster result_cluster, GeneralInfo info) {\r\n DefaultMutableTreeNode root = new DefaultMutableTreeNode(\"GLOBANC\");\r\n addResultNodes(root, result_cluster, info);\r\n return root;\r\n }", "public NsSearchResult<RecT> search() {\n Object searchRecord = toNativeQuery();\n NsSearchResult<RecT> result = clientService.search(searchRecord);\n if (!result.isSuccess()) {\n NetSuiteClientService.checkError(result.getStatus());\n }\n return result;\n }", "public abstract Search create(String search, SearchBuilder builder);", "protected SearchNode createNewNode( int x, int y, int z, float g, float h,\n\t\t\t\t\t SearchNode predecessor,\n\t\t\t\t\t byte searchStatus ) {\n\t\treturn new SearchNode( x, y, z, g, h, predecessor, searchStatus );\n\t}", "protected void addResultNodes(DefaultMutableTreeNode root, Cluster result_cluster, GeneralInfo info) {\r\n addExpressionImages(root);\r\n// addHierarchicalTrees(root, result_cluster, info);\r\n// addCentroidViews(root);\r\n addTableViews(root);\r\n addGeneSetInfo(root);\r\n// addClusterInfo(root);\r\n \r\n addGeneralInfo(root, info);\r\n }", "SearchResult search(State root, List<State> expanded_list, State goal);", "entities.Torrent.LocalSearchResponseOrBuilder getLocalSearchResponseOrBuilder();", "public static <T, ST extends T, P extends Enum<?> & SearchParameter> SearchResponseBuilder<T, ST, P> create(\n Class<T> responseClass, Class<ST> annotatedClass, BiMap<String, P> facetFieldsPropertiesMap,\n BiMap<String, String> fieldPropertyPropertiesMap) {\n\n return new SearchResponseBuilder<T, ST, P>(responseClass, annotatedClass, facetFieldsPropertiesMap,\n fieldPropertyPropertiesMap);\n }", "SearchResultsType createSearchResultsType();", "private Node(com.google.protobuf.GeneratedMessageV3.Builder<?> builder) {\n super(builder);\n }", "public SearchDocument() {\n super();\n }", "public StreetSearcher() {\n vertices = new HashMap<>();\n graph = new SparseGraph<>();\n //double smDistance = 0;\n //previous = new HashMap<>();\n }", "public SearchResult(String location) {\n\t\t\tthis.location = location;\n\t\t\tthis.count = 0;\n\t\t\tthis.score = 0;\n\t\t}", "private LookupResult(Builder builder) {\n super(builder);\n }", "protected SearchNode<T> getOrAddSearchNode( Node<T> node ) {\n\t\tif ( node == null ) {\n\t\t\tthrow new IllegalArgumentException( \"Null node\" );\n\t\t}\n\t\tif ( ! searchNodes.containsKey( node.getNodeId() ) ) {\n\t\t\tsearchNodes.put( node.getNodeId(), node instanceof SearchNode ? (SearchNode)node : new SearchNode<>( node ) );\n\t\t}\n\t\treturn searchNodes.get( node.getNodeId() );\n\t}", "SearchResult<TimelineMeta> search(SearchParameter searchParameter);", "public ReactorResult<org.ontoware.rdf2go.model.node.Node> getAllEncodedBy_asNode_() {\r\n\t\treturn Base.getAll_as(this.model, this.getResource(), ENCODEDBY, org.ontoware.rdf2go.model.node.Node.class);\r\n\t}", "public entities.Torrent.LocalSearchResponse.Builder getLocalSearchResponseBuilder() {\n\n onChanged();\n return getLocalSearchResponseFieldBuilder().getBuilder();\n }", "TSearchQuery createSearchQuery(SearchQueryDefinitionAPI searchQueryDefinition);", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public entities.Torrent.SearchResponse.Builder getSearchResponseBuilder() {\n\n onChanged();\n return getSearchResponseFieldBuilder().getBuilder();\n }", "SearchResult findNext(SearchResult result);", "@Override\r\n protected List<SearchResult> doInBackground(String... params) {\n if (searchResults == null)\r\n searchResults = new ArrayList<SearchResult>();\r\n\r\n return searchResults;\r\n\r\n }", "@Override\n protected SearchResponse compute() {\n if (this.searchRoot.children == null || this.searchRoot.children.isEmpty()) {\n return new SearchResponse(searchRoot.weight, null);\n }\n\n // Search child nodes recursively\n List<UnbalancedNodeSearcher> subtasks = new ArrayList<>(searchRoot.children.size());\n for (Node n : searchRoot.children) {\n UnbalancedNodeSearcher subtask = new UnbalancedNodeSearcher(n);\n subtasks.add(subtask);\n subtask.fork();\n }\n\n // Use a map to vote for the \"wrong\"(i.e. minority) disc weight\n Map<Long, AtomicLong> totalWeight = new HashMap<>();\n\n // To find out who reported the \"wrong\" weight\n Map<Long, Node> resultNodeMap = new HashMap<>();\n for (UnbalancedNodeSearcher searcher : subtasks) {\n SearchResponse response = searcher.join();\n\n // The search is over\n if (response.foundResult != null) {\n return response;\n }\n\n resultNodeMap.put(response.subSum, searcher.searchRoot);\n\n totalWeight.computeIfAbsent(response.subSum, (i) -> new AtomicLong(0L)).incrementAndGet();\n }\n\n if (totalWeight.size() == 1) {\n // Since there's only one\n long subtotal = totalWeight.keySet().iterator().next();\n long total = subtotal * subtasks.size() + searchRoot.weight;\n\n return new SearchResponse(total, null);\n } else if (totalWeight.size() == 2) {\n long correctWeight = -1;\n long wrongWeight = -1;\n for (Map.Entry<Long, AtomicLong> entry : totalWeight.entrySet()) {\n if (entry.getValue().get() != 1L) {\n correctWeight = entry.getKey();\n } else {\n wrongWeight = entry.getKey();\n }\n }\n\n return new SearchResponse(null, resultNodeMap.get(wrongWeight).weight - (wrongWeight - correctWeight));\n } else {\n throw new RuntimeException(\"More than one incorrect nodes\");\n }\n }", "public SearchResult(String location, int count, double score) {\n\t\t\tthis.location = location;\n\t\t\tthis.count = count;\n\t\t\tthis.score = score;\n\t\t}", "public static QueryResult fromDiscoveryResult(QueryResponse response) {\n return new QueryResult.Builder()\n .content(response.getResults().get(0).get(\"text\").toString())\n .filename(response.getResults().get(0).getTitle())\n .build();\n }", "void remoteSearch(String groupId, String type, String attr, \n String value, int threshold, String serviceHandler, \n DiscoveryListener listener)\n \tthrows IOException\n {\n Query query = new Query(groupId, type, attr, value, \n serviceHandler,listener);\n \n queries.put(listener, query);\n \n\t //if resource not found in local cache\n\t String requestId = getNextRequestId();\n\t \n\t int urisize =0;\n\t EndpointAddress[] myURIs = peer.getURIList();\n\t \n\t if (myURIs != null)\n\t urisize = myURIs.length;\n\t \n\t Element[] elm = new Element[9 + urisize];\n\t //Element[] elm = new Element[9];\n\t \n\t\n\t elm[0] = new Element(Message.MESSAGE_TYPE_TAG, Message.REQUEST_SEARCH,\n\t Message.JXTA_NAME_SPACE);\n\t elm[1] = new Element(Message.TYPE_TAG, type, \n\t Message.JXTA_NAME_SPACE);\n\t elm[2] = new Element(Message.ATTRIBUTE_TAG, attr, \n\t Message.JXTA_NAME_SPACE);\n\t elm[3] = new Element(Message.VALUE_TAG, value, \n\t Message.JXTA_NAME_SPACE);\n\t elm[4] = new Element(Message.THRESHOLD_TAG, Integer.toString(threshold), \n\t Message.JXTA_NAME_SPACE);\n\t elm[5] = new Element(Message.REQUESTID_TAG, requestId, \n\t Message.JXTA_NAME_SPACE);\n\t elm[6] = new Element(Message.ID_TAG, peer.getID().toString(), \n\t Message.JXTA_NAME_SPACE);\n\t elm[7] = new Element(Message.GROUP_ID_TAG, groupId, \n\t Message.JXTA_NAME_SPACE);\n\t elm[8] = new Element(Message.HOPCOUNT_TAG, Integer.toString(DEFAULT_HOP_COUNT), \n\t Message.JXTA_NAME_SPACE);\n\t\n\t if (urisize > 0)\n\t {\n\t\t for (int i = 0; i < myURIs.length; i++)\n\t\t {\n\t\t EndpointAddress uri = myURIs[i];\n\t\t uri = new EndpointAddress(uri, serviceName, serviceHandler);\n\t\t elm[9 + i] = new Element(NamedResource.URITAG + String.valueOf(i), uri.toString().getBytes(),\n\t\t Message.JXTA_NAME_SPACE, null);\n\t\t }\n\t }\n\t \n\t send(elm, serviceHandler);\n }", "public MagicSearch createMagicSearch();", "public static AccSearchResponse parse(\r\n javax.xml.stream.XMLStreamReader reader)\r\n throws java.lang.Exception {\r\n AccSearchResponse object = new AccSearchResponse();\r\n\r\n int event;\r\n javax.xml.namespace.QName currentQName = null;\r\n java.lang.String nillableValue = null;\r\n java.lang.String prefix = \"\";\r\n java.lang.String namespaceuri = \"\";\r\n\r\n try {\r\n while (!reader.isStartElement() && !reader.isEndElement())\r\n reader.next();\r\n\r\n currentQName = reader.getName();\r\n\r\n if (reader.getAttributeValue(\r\n \"http://www.w3.org/2001/XMLSchema-instance\",\r\n \"type\") != null) {\r\n java.lang.String fullTypeName = reader.getAttributeValue(\"http://www.w3.org/2001/XMLSchema-instance\",\r\n \"type\");\r\n\r\n if (fullTypeName != null) {\r\n java.lang.String nsPrefix = null;\r\n\r\n if (fullTypeName.indexOf(\":\") > -1) {\r\n nsPrefix = fullTypeName.substring(0,\r\n fullTypeName.indexOf(\":\"));\r\n }\r\n\r\n nsPrefix = (nsPrefix == null) ? \"\" : nsPrefix;\r\n\r\n java.lang.String type = fullTypeName.substring(fullTypeName.indexOf(\r\n \":\") + 1);\r\n\r\n if (!\"AccSearchResponse\".equals(type)) {\r\n //find namespace for the prefix\r\n java.lang.String nsUri = reader.getNamespaceContext()\r\n .getNamespaceURI(nsPrefix);\r\n\r\n return (AccSearchResponse) ExtensionMapper.getTypeObject(nsUri,\r\n type, reader);\r\n }\r\n }\r\n }\r\n\r\n // Note all attributes that were handled. Used to differ normal attributes\r\n // from anyAttributes.\r\n java.util.Vector handledAttributes = new java.util.Vector();\r\n\r\n reader.next();\r\n\r\n while (!reader.isStartElement() && !reader.isEndElement())\r\n reader.next();\r\n\r\n if ((reader.isStartElement() &&\r\n new javax.xml.namespace.QName(\r\n \"http://tempuri.org/\", \"AccSearchResult\").equals(\r\n reader.getName())) ||\r\n new javax.xml.namespace.QName(\"\", \"AccSearchResult\").equals(\r\n reader.getName())) {\r\n nillableValue = reader.getAttributeValue(\"http://www.w3.org/2001/XMLSchema-instance\",\r\n \"nil\");\r\n\r\n if (\"true\".equals(nillableValue) ||\r\n \"1\".equals(nillableValue)) {\r\n throw new org.apache.axis2.databinding.ADBException(\r\n \"The element: \" + \"AccSearchResult\" +\r\n \" cannot be null\");\r\n }\r\n\r\n java.lang.String content = reader.getElementText();\r\n\r\n object.setAccSearchResult(org.apache.axis2.databinding.utils.ConverterUtil.convertToString(\r\n content));\r\n\r\n reader.next();\r\n } // End of if for expected property start element\r\n\r\n else {\r\n }\r\n\r\n while (!reader.isStartElement() && !reader.isEndElement())\r\n reader.next();\r\n\r\n if (reader.isStartElement()) {\r\n // 2 - A start element we are not expecting indicates a trailing invalid property\r\n throw new org.apache.axis2.databinding.ADBException(\r\n \"Unexpected subelement \" + reader.getName());\r\n }\r\n } catch (javax.xml.stream.XMLStreamException e) {\r\n throw new java.lang.Exception(e);\r\n }\r\n\r\n return object;\r\n }", "public SearchResponse(String from, String to, UUID uuid, String error) {\r\n super(from, to, new JSONObject()\r\n .put(\"type\", MessageType.SEARCH_RESPONSE.name())\r\n .put(\"status\", \"error\")\r\n .put(\"id\", uuid.toString())\r\n .put(\"message\", error));\r\n }", "ReagentSearch getReagentSearch();", "@java.lang.Override\n public entities.Torrent.SearchResponseOrBuilder getSearchResponseOrBuilder() {\n return getSearchResponse();\n }", "public EntrezSearcher (String query, String folderPath){\n this(\"pubmed\",\"xml\", query,folderPath);\n }", "private AbstractJSObject createNodeWrapper(Node node) {\n return new XmlNodeWrapper(node);\n }", "Search getSearch();", "public search_result(search_result other) {\n if (other.isSetSuccess()) {\n this.success = new com.mkfree.apithrift.vo.SearchResultVO(other.success);\n }\n }", "public SearchResponse search(SearchRequest request) throws SearchServiceException;" ]
[ "0.6980751", "0.6913029", "0.6488908", "0.64627886", "0.61480916", "0.61405337", "0.6042157", "0.60344315", "0.60204875", "0.59901774", "0.59735817", "0.59578556", "0.58895224", "0.5818193", "0.5810673", "0.57686347", "0.5498294", "0.54823244", "0.54363775", "0.5396493", "0.53883195", "0.5365259", "0.5362245", "0.5350777", "0.5335647", "0.52375257", "0.5209837", "0.5207013", "0.51982296", "0.5196148", "0.5173656", "0.51657367", "0.5119482", "0.5117758", "0.50752735", "0.50719315", "0.507092", "0.5062453", "0.5016543", "0.49788418", "0.4975364", "0.49729535", "0.49687913", "0.49621812", "0.49530604", "0.49522215", "0.49372536", "0.49355644", "0.49000567", "0.48670015", "0.48579305", "0.48560736", "0.48521602", "0.4846287", "0.4845753", "0.483874", "0.48222762", "0.481921", "0.4817497", "0.4812052", "0.4810335", "0.47967952", "0.47955203", "0.4786673", "0.47756234", "0.47719163", "0.47698587", "0.47649136", "0.47522882", "0.47445738", "0.47404793", "0.4739527", "0.47300133", "0.47242934", "0.47188613", "0.47145128", "0.470658", "0.47020096", "0.47012934", "0.46998772", "0.46998772", "0.46998772", "0.46998772", "0.46838883", "0.46821243", "0.4663144", "0.46617445", "0.4657386", "0.46566933", "0.4646855", "0.4634789", "0.46340945", "0.4632283", "0.46290198", "0.4625285", "0.4618789", "0.46132225", "0.4609784", "0.4609344", "0.45969385" ]
0.73774797
0
.NodeId node = 1;
@java.lang.Override public boolean hasNode() { return node_ != null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
@java.lang.Override public entities.Torrent.NodeId getNode() { return node_ == null ? entities.Torrent.NodeId.getDefaultInstance() : node_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
@java.lang.Override public entities.Torrent.NodeIdOrBuilder getNodeOrBuilder() { return getNode(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.Status status = 2;
@java.lang.Override public int getStatusValue() { return status_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
.Status status = 2;
@java.lang.Override public entities.Torrent.Status getStatus() { @SuppressWarnings("deprecation") entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_); return result == null ? entities.Torrent.Status.UNRECOGNIZED : result; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
string errorMessage = 3;
@java.lang.Override public java.lang.String getErrorMessage() { java.lang.Object ref = errorMessage_; if (ref instanceof java.lang.String) { return (java.lang.String) ref; } else { com.google.protobuf.ByteString bs = (com.google.protobuf.ByteString) ref; java.lang.String s = bs.toStringUtf8(); errorMessage_ = s; return s; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59142876", "0.59142876", "0.59142876", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.0
-1
string errorMessage = 3;
@java.lang.Override public com.google.protobuf.ByteString getErrorMessageBytes() { java.lang.Object ref = errorMessage_; if (ref instanceof java.lang.String) { com.google.protobuf.ByteString b = com.google.protobuf.ByteString.copyFromUtf8( (java.lang.String) ref); errorMessage_ = b; return b; } else { return (com.google.protobuf.ByteString) ref; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59142876", "0.59142876", "0.59142876", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.0
-1
repeated .FileInfo files = 4;
@java.lang.Override public java.util.List<entities.Torrent.FileInfo> getFilesList() { return files_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.0
-1
repeated .FileInfo files = 4;
@java.lang.Override public java.util.List<? extends entities.Torrent.FileInfoOrBuilder> getFilesOrBuilderList() { return files_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.0
-1
repeated .FileInfo files = 4;
@java.lang.Override public int getFilesCount() { return files_.size(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.5268754
62
repeated .FileInfo files = 4;
@java.lang.Override public entities.Torrent.FileInfo getFiles(int index) { return files_.get(index); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.0
-1
repeated .FileInfo files = 4;
@java.lang.Override public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder( int index) { return files_.get(index); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.5335172
45
.NodeId node = 1;
public boolean hasNode() { return nodeBuilder_ != null || node_ != null; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public entities.Torrent.NodeId getNode() { if (nodeBuilder_ == null) { return node_ == null ? entities.Torrent.NodeId.getDefaultInstance() : node_; } else { return nodeBuilder_.getMessage(); } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public Builder setNode(entities.Torrent.NodeId value) { if (nodeBuilder_ == null) { if (value == null) { throw new NullPointerException(); } node_ = value; onChanged(); } else { nodeBuilder_.setMessage(value); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public Builder setNode( entities.Torrent.NodeId.Builder builderForValue) { if (nodeBuilder_ == null) { node_ = builderForValue.build(); onChanged(); } else { nodeBuilder_.setMessage(builderForValue.build()); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public Builder mergeNode(entities.Torrent.NodeId value) { if (nodeBuilder_ == null) { if (node_ != null) { node_ = entities.Torrent.NodeId.newBuilder(node_).mergeFrom(value).buildPartial(); } else { node_ = value; } onChanged(); } else { nodeBuilder_.mergeFrom(value); } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public Builder clearNode() { if (nodeBuilder_ == null) { node_ = null; onChanged(); } else { node_ = null; nodeBuilder_ = null; } return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public entities.Torrent.NodeId.Builder getNodeBuilder() { onChanged(); return getNodeFieldBuilder().getBuilder(); }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
public entities.Torrent.NodeIdOrBuilder getNodeOrBuilder() { if (nodeBuilder_ != null) { return nodeBuilder_.getMessageOrBuilder(); } else { return node_ == null ? entities.Torrent.NodeId.getDefaultInstance() : node_; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.NodeId node = 1;
private com.google.protobuf.SingleFieldBuilderV3< entities.Torrent.NodeId, entities.Torrent.NodeId.Builder, entities.Torrent.NodeIdOrBuilder> getNodeFieldBuilder() { if (nodeBuilder_ == null) { nodeBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< entities.Torrent.NodeId, entities.Torrent.NodeId.Builder, entities.Torrent.NodeIdOrBuilder>( getNode(), getParentForChildren(), isClean()); node_ = null; } return nodeBuilder_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setNode_1(String node_1);", "NodeId getNodeId();", "void nodeCreate( long id );", "public void setNode_2(String node_2);", "public void setNode_3(String node_3);", "public void setNode_5(String node_5);", "public void setNode_4(String node_4);", "entities.Torrent.NodeId getNode();", "entities.Torrent.NodeId getNode();", "public void setNode(String node)\n {\n this.node = node;\n }", "public void setNode(String node) {\n this.node = node;\n }", "String getIdNode1();", "public String getNodeId() {\r\n return nodeId;\r\n }", "void setNode(int nodeId, double lat, double lon, double ele);", "void setNode(int nodeId, double lat, double lon);", "boolean addNode(long idNum, String label);", "public void setNodeId(String nodeId) {\r\n this.nodeId = nodeId;\r\n }", "public int Node() { return this.Node; }", "String getIdNode2();", "public void setNodeA(int x){\n this.nodeA = x;\n }", "Node(int value, String name) {\n this.value = value;\n this.name = name;\n }", "public NodeId getNodeId() {\n return nodeId;\n }", "public Long getNodeId() {\n return nodeId;\n }", "public int getAD_WF_Node_ID();", "void addNode(int node);", "public String getNodeId() {\n return nodeId;\n }", "public String getNodeId() {\n return nodeId;\n }", "public int getNodeID() {\n return nodeID;\n }", "public void AddNode(StubNode node) {\n\n }", "public String getId() {\n return _node_id;\n }", "void newNode(int nodeId) {\n window.newNode(nodeId);\n }", "public UUID nodeId();", "public int getNodeLabel ();", "public String getNode_id() {\r\n\t\treturn node_id;\r\n\t}", "public void setIdentifier(IdentifierNode identifier);", "public String getNodeId() {\r\n\t\treturn nodeId;\r\n\t}", "public int getNodeID() {\r\n \t\treturn nodeID;\r\n \t}", "public void setNodeId(Long nodeId) {\n this.nodeId = nodeId;\n }", "N getNode(int id);", "public Node( String id )\r\n {\r\n initialize(id);\r\n lbl = id;\r\n }", "public String getNodeId() {\n\t\treturn nodeId;\n\t}", "public void setID(String s) {\r\n\t\tthis.idNode = s;\r\n\t}", "public void set_nodeid(short value) {\n setUIntBEElement(offsetBits_nodeid(), 8, value);\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public void setNodeId(String nodeId) {\n this.nodeId = nodeId;\n }", "public String nodeId() {\n return this.nodeId;\n }", "protected void NewIdentity()\n\t{\n\t\tthis.identity=0L;\n\t\tNodeReference nodeRef = getNodeReference();\n\t\tnodeRef.appendSubscript(0L);\n\t\tnodeRef.appendSubscript(\"id\");\n\t\tthis.identity=nodeRef.increment(1);\n\t}", "public MyNode() {\r\n\t\tdefine(\"load\",new Integer(getID()),true);\r\n }", "public void setFun(IdUse node) {\n setChild(node, 0);\n }", "public Depot (String id, int node){\r\n this.id=id;\r\n this.node=node;\r\n }", "public void setNode(int _data ) {\r\n\t\t\tdata = _data;\r\n\t\t}", "@Test\r\n public void testSetId_getId() {\r\n System.out.println(\"getId\");\r\n ConfigNode configNode = new ConfigNode(testLine);\r\n configNode.setId(\"id1\");\r\n assertEquals(\"id1\", configNode.getId());\r\n }", "public int getNodeA(){\n return this.nodeA;\n }", "public void setAD_WF_Node_ID (int AD_WF_Node_ID);", "public static void QuestionOne(Node n) {\n\n\n\n }", "public node(String ID) {\n\t\t// TODO Auto-generated constructor stub\n\t\tname = ID;\n\t\tcomment_centrality = -1;\n\t\tlike_centrality = -1;\n\t}", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "entities.Torrent.NodeIdOrBuilder getNodeOrBuilder();", "public Node(final String id) {\n super();\n this.id = id;\n }", "public abstract void setNodes();", "void setNode(String path, Node node)\n throws ProcessingException;", "public long getNodeID()\n {\n return vnodeid; \n }", "ControllerNode localNode();", "@Override\r\n public void nodeActivity() {\n }", "@Override\n public String getId() {\n return \"1\";\n }", "public NonceHelperImpl(Node node) {\n\t\tthis.node = node;\n\t}", "@AutoEscape\n\tpublic String getNode_1();", "public NodeId getId() {\n return id;\n }", "public Node() {}", "public Node() {}", "public Node() {}", "public Node() {}", "public void setValue(int node, Type value) {\n\t\tvalues[node] = value;\n\t}", "public int getNodeId() {\n return m_nodeId;\n }", "void setLowNode(Node n){\n low = n;\n }", "public Node()\r\n {\r\n initialize(null);\r\n lbl = id;\r\n }", "Node getNode();", "@Override\n\tpublic void setNode_1(java.lang.String node_1) {\n\t\t_dictData.setNode_1(node_1);\n\t}", "public void root(Node n) {}", "OperationNode getNode();", "void addHasNodeID(Integer newHasNodeID);", "public Node() {\n\n }", "Node(int newId)\n {\n connectedNodes = new ArrayList<Node>();\n id = newId;\n weight = 0;\n }", "public IdentifierNode getIdentifier()throws ClassCastException;", "public abstract void setSelectedNode(String n);", "public short getNode() {\n return node;\n }", "public Event setNode(String node) {\n this.node = node;\n return this;\n }", "public String getPrefix() { return \"linknode\"; }", "public String getNodeValue ();", "private void parseId(Node node) {\r\n if (switchTest) return;\r\n skipTrace = true;\r\n parse(node.ref());\r\n }", "void setFirst(Node node) {\n this.first = node;\n }", "public void setNode(ResidentNode node) {\r\n\t\tthis.node = node;\r\n//\t\tif (this.node != null && this.node.getMFrag() != null) {\r\n//\t\t\tthis.mebn = this.node.getMFrag().getMultiEntityBayesianNetwork();\r\n//\t\t}\r\n\t}", "public String getID() {\r\n\t\treturn this.idNode;\r\n\t}", "public void setCurrentNode(int node) {\n\t\tthis.currentNode = node;\n\t}", "private MsoSmartArtNodePosition(int value) { this.value = value; }", "public abstract int getNodeType();", "private void setNodeVersion(int nodeVersion) {\n this.nodeVersion = nodeVersion;\r\n }", "public NodeKey createNodeKey();", "public Node(int value) {\n\t\tthis.value = value;\n\t}", "public Node(String name) {\n this.name = name;\n }", "public String getNodeIdString()\r\n\t{\r\n\t\treturn nodeIdString;\r\n\t}" ]
[ "0.73256433", "0.6852427", "0.6849394", "0.6806979", "0.67361647", "0.6719867", "0.6702744", "0.66503185", "0.66503185", "0.66468775", "0.65969825", "0.65160197", "0.6454553", "0.6443028", "0.6397236", "0.6352641", "0.6350317", "0.63298136", "0.6328935", "0.63250077", "0.6289688", "0.6270069", "0.6263843", "0.6253402", "0.6252804", "0.62449926", "0.62449926", "0.6208573", "0.62077785", "0.61956346", "0.61759245", "0.61752164", "0.6168949", "0.61664915", "0.61636734", "0.6151134", "0.6132329", "0.6129818", "0.610544", "0.61033696", "0.60988986", "0.60834545", "0.6080666", "0.60322636", "0.60322636", "0.6030647", "0.60273737", "0.60076797", "0.5993974", "0.5991894", "0.5975315", "0.5966923", "0.5957979", "0.59423155", "0.5933431", "0.5932226", "0.5917212", "0.5917212", "0.5898032", "0.58931583", "0.58868676", "0.5860643", "0.5859668", "0.5856169", "0.5856013", "0.5853909", "0.5843917", "0.58435774", "0.5829975", "0.5829975", "0.5829975", "0.5829975", "0.5804296", "0.580218", "0.5800363", "0.57965004", "0.57952", "0.5785294", "0.5781936", "0.5780336", "0.57703656", "0.57555526", "0.5749264", "0.5749088", "0.5734936", "0.57123274", "0.57085574", "0.56990063", "0.5697113", "0.5691158", "0.56839514", "0.5656944", "0.56531805", "0.56502795", "0.56449527", "0.5635717", "0.5634889", "0.56326395", "0.5627951", "0.562447", "0.5618776" ]
0.0
-1
.Status status = 2;
@java.lang.Override public int getStatusValue() { return status_; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
.Status status = 2;
public Builder setStatusValue(int value) { status_ = value; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
.Status status = 2;
@java.lang.Override public entities.Torrent.Status getStatus() { @SuppressWarnings("deprecation") entities.Torrent.Status result = entities.Torrent.Status.valueOf(status_); return result == null ? entities.Torrent.Status.UNRECOGNIZED : result; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
.Status status = 2;
public Builder setStatus(entities.Torrent.Status value) { if (value == null) { throw new NullPointerException(); } status_ = value.getNumber(); onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
.Status status = 2;
public Builder clearStatus() { status_ = 0; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "public void setStatus(EnumVar status) {\n this.status = status;\n }", "public void setStatus(String status) { this.status = status; }", "void setStatus(STATUS status);", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\r\n this.status = status;\r\n }", "public Status getStatus(){\n return status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Integer status) {\n this.status = status;\n }", "public void setStatus(Status status) {\r\n\t this.status = status;\r\n\t }", "private void setStatus(com.google.protobuf.ByteString value) {\n if (value == null) {\n throw new NullPointerException();\n }\n \n status_ = value;\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "public void setStatus(Byte status) {\r\n this.status = status;\r\n }", "void setStatus(int status);", "public void setStatus(int status){\r\n\t\tthis.status=status;\r\n\t}", "public void setStatus(int status) {\n STATUS = status;\n }", "public void setStatus(long status) {\r\n this.status = status;\r\n }", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Integer status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(String stat)\n {\n status = stat;\n }", "public void setStatus(int status);", "public void setStatus(int status);", "public void setStatus(Status newStatus){\n status = newStatus;\n }", "public void setStatus(java.lang.Object status) {\n this.status = status;\n }", "public void setStatus(StatusEnum status) {\n this.status = status;\n }", "public void setStatus(int v) \n {\n \n if (this.status != v)\n {\n this.status = v;\n setModified(true);\n }\n \n \n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\n this.status = status;\n }", "public void setgetStatus()\r\n\t{\r\n\t\tthis.status = 'S';\r\n\t}", "messages.Statusmessage.StatusMessage getStatus();", "public void setStatus(String newStatus){\n\n //assigns the value of newStatus to the status field\n this.status = newStatus;\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(int status) {\n this.status = status;\n }", "public void setStatus(Byte status) {\r\n\t\tthis.status = status;\r\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Byte status) {\n\t\tthis.status = status;\n\t}", "void mo9948a(Status cVar);", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public StatusCode GetStatus();", "public final Status getStatus() {\n/* 199 */ return this.status;\n/* */ }", "public void setStatus(STATUS status) {\n this.status = status;\n }", "public void setStatus(Status status)\n {\n this.status = status;\n }", "public StatusEnum getStatus()\n {\n return status;\n }", "public void setStatus(Boolean s){ status = s;}", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(String status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n this.status = status;\n }", "public void setStatus( Short status ) {\n this.status = status;\n }", "@Override\n\t\tpublic void setStatus(int status) {\n\t\t\t\n\t\t}", "void setStatus(String status);", "public void setStatus(Status status) {\r\n this.status = status;\r\n }", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public void setStatus(Short status) {\n\t\tthis.status = status;\n\t}", "public EnumVar getStatus() {\n return status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }", "public void setStatus(String status) {\n this.status = status;\n }" ]
[ "0.73907614", "0.73554754", "0.73374486", "0.7327968", "0.7327968", "0.7323023", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.72633004", "0.7247881", "0.72306985", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7230474", "0.7229459", "0.7216606", "0.72078234", "0.7205608", "0.7203075", "0.7203075", "0.7198453", "0.7195646", "0.7195646", "0.71802807", "0.7176719", "0.71681315", "0.716781", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.7167687", "0.71580833", "0.71410364", "0.71322036", "0.712795", "0.7126239", "0.7126239", "0.7117732", "0.71150094", "0.71150094", "0.71086705", "0.7103983", "0.7103983", "0.7099431", "0.7095314", "0.7092456", "0.70844", "0.70814365", "0.70792097", "0.70755166", "0.70755166", "0.7075151", "0.70546657", "0.7054579", "0.7047856", "0.7046609", "0.7043516", "0.7043516", "0.70082664", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436", "0.70019436" ]
0.0
-1
string errorMessage = 3;
public java.lang.String getErrorMessage() { java.lang.Object ref = errorMessage_; if (!(ref instanceof java.lang.String)) { com.google.protobuf.ByteString bs = (com.google.protobuf.ByteString) ref; java.lang.String s = bs.toStringUtf8(); errorMessage_ = s; return s; } else { return (java.lang.String) ref; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.59148765
55
string errorMessage = 3;
public com.google.protobuf.ByteString getErrorMessageBytes() { java.lang.Object ref = errorMessage_; if (ref instanceof String) { com.google.protobuf.ByteString b = com.google.protobuf.ByteString.copyFromUtf8( (java.lang.String) ref); errorMessage_ = b; return b; } else { return (com.google.protobuf.ByteString) ref; } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59142876", "0.59142876", "0.59142876", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.0
-1
string errorMessage = 3;
public Builder setErrorMessage( java.lang.String value) { if (value == null) { throw new NullPointerException(); } errorMessage_ = value; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59142876", "0.59142876", "0.59142876", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.0
-1
string errorMessage = 3;
public Builder clearErrorMessage() { errorMessage_ = getDefaultInstance().getErrorMessage(); onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59142876", "0.59142876", "0.59142876", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.0
-1
string errorMessage = 3;
public Builder setErrorMessageBytes( com.google.protobuf.ByteString value) { if (value == null) { throw new NullPointerException(); } checkByteStringIsUtf8(value); errorMessage_ = value; onChanged(); return this; }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "String errorMessage();", "String getErrorMessage();", "String getErrorMessage();", "private void error(String string) {\n\t\r\n}", "java.lang.String getError();", "java.lang.String getError();", "java.lang.String getError();", "String getError(int i) {\n if (i >= 0 & i < msgs.length)\n return msgs[i];\n else\n return \"Invalid Error Code\";\n }", "void showErrorMsg(String string);", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "java.lang.String getErrorMessage();", "String getGetErrorMessage();", "java.lang.String getErr();", "public String getErrorString()\r\n\t{\r\n\t\t\r\n\t\treturn ERROR_STRING;\r\n\t}", "String getErrorsString();", "public String error();", "String getInvalidMessage();", "private static String getMessage(int code) {\n switch (code) {\n case ME_DIV_BY_ZERO:\n return \"Attempt to divide by zero.\";\n case ME_ASSIGNLITERAL:\n return \"Attempt to assign to a literal.\";\n case ME_NONVARASSIGN:\n return \"Attempt to assign to a non-variable.\";\n default:\n return \"Unknown error.\";\n }\n }", "public String getError() {\n\treturn mistake;\n }", "public void error(String string) {\n\t\t\n\t}", "private String getErrorString() {\n\t\treturn \"GUID:ERROR:\" + mErrors[0][0]\n\t\t + \":\" + mErrors[1][0]\n\t\t + \":\" + mErrors[2][0]\n\t\t + \":\" + mErrors[3][0];\n\t}", "public java.lang.String getErrorMessage(){\n return localErrorMessage;\n }", "public static String getLastErrorMessage()\r\n\t{\n\t\treturn lastAlert;\r\n\t}", "public String getErrorMessage() \r\n\t{\r\n\t\t\r\n\t\treturn errorMessage;\r\n\t\t\r\n\t}", "String getMessage();", "String getMessage();", "String getMessage();", "String getErrorMessage(E input);", "public String getErrorString()\n\t{\n\t\treturn errorString;\n\t}", "java.lang.String getErrmsg();", "public String errorMessage()\n {\n return new String(errorMessageAsBytes());\n }", "public String getErrorString(String message) {\n \t\treturn getString(new StringBuffer(\"error.\").append(message).toString());\n \t}", "public String errorMessage() {\n return errorMessage;\n }", "private int getErrorId(final String message) {\n\t\tif (isLowerCase(message)) {\n\t\t\treturn ERROR_LOWER_CASE;\n\t\t} else if (isUnunsedMacro(message)) {\n\t\t\treturn ERROR_UNUSED_MACRO;\n\t\t} else if (isUnunsedVariable(message)) {\n\t\t\treturn ERROR_UNUSED_VARIABLE;\n\t\t} else if (isEndLineSpace(message) || isNoSpace(message)) {\n\t\t\treturn ERROR_NO_SPACE;\n\t\t} else if (isOneSpace(message)) {\n\t\t\treturn ERROR_ONE_SPACE;\n\t\t} else {\n\t\t\treturn ERROR_INVALID;\n\t\t}\n\t}", "void showError(String errorMessage);", "public String getErrorMessage()\n {\n return errorMessage;\n }", "String Message ();", "public String getError() {\r\n if (scriptError == null) return \"\";\r\n return scriptError;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n if (bs.isValidUtf8()) {\n errorMessage_ = s;\n }\n return s;\n }\n }", "public String errorMessage()\n {\n return edma_errorMsg;\n }", "public String getError() {\n return errMsg;\n }", "public String getMsgError() {\r\n\t\treturn msgError;\r\n\t}", "public String getErrorMessage() {\r\n return this.errorMessage;\r\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "void showError(@StringRes int errorMessage);", "private String getGUIErrorMsg(long errorcode) {\n\t\tif (errorcode == 0) {\n\t\t\treturn \"This popup shouldn't have launched!\";\n\t\t} else if (errorcode == 9) {\n\t\t\treturn \"Latitude input format incorrect!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 10) {\n\t\t\treturn \"Longitude input format incorrect!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 11) {\n\t\t\treturn \"Date input format incorrect!\\nValid dates go <year>-<month>-<day>\\nValid month values are 1- 12 and valid day values are 1 - 31.\";\n\t\t} else if (errorcode == 12) {\n\t\t\treturn \"Time input format incorrect!\\nValid times go <hour>-<minute>-<second>\\nValid hour values are 0 - 23 and valid minute and second values are 0 - 59\";\n\t\t} else if (errorcode == 1) {\n\t\t\treturn \"Invalid latitude!\\nValid Latitude values are -90 to 90 with negative values being south Latitude.\";\n\t\t} else if (errorcode == 2) {\n\t\t\treturn \"Invalid Longitude!\\nValid Longitude values are -180 to 180 with negative values being west latitude.\";\n\t\t} else if (errorcode == 3) {\n\t\t\treturn \"Invalid Year!\\nValid year values are \" + Integer.MIN_VALUE + \" - \" + Integer.MAX_VALUE + \".\";\n\t\t} else if (errorcode == 4) {\n\t\t\treturn \"Invalid Month!\\nValid month values are 1 - 12\";\n\t\t} else if (errorcode == 5) {\n\t\t\treturn \"Invalid Day!\\nValid day values are 1 - 31\";\n\t\t} else if (errorcode == 6) {\n\t\t\treturn \"Invalid Hour!\\nValid hour values are 0 - 23\";\n\t\t} else if (errorcode == 7) {\n\t\t\treturn \"Invalid Minute!\\nValid minute values are 0 - 59\";\n\t\t} else if (errorcode == 8) {\n\t\t\treturn \"Invalid Second!\\nValid second values are 0 - 59\";\n\t\t} \n\t\treturn \"Undefined Error Message!\";\n\t}", "void SemErr(String str);", "public String errorMessage() {\n return this.errorMessage;\n }", "static int errorMsg(int eCode)\n {\n if (eCode == 0) return 0;\n String message = \"\";\n switch (eCode){\n case 1: message = \"Division by zero\"; break;\n case 2: message = \"Non-matching parenthesis in function\"; break;\n case 3: message = \"Must enclose negative exponents in parentheses\"; break;\n case 4: message = \"Incorrect Operator Syntax\"; break;\n case 5: message = \"Rightfunctions must use parenthesis. (example: ABS(-2);\"; break;\n case 6: message = \"Unrecognized token in function srtring.\"; break;\n case 8: message = \"Can not raise negative number to a fractional power.\"; break;\n case 10:message = \"Input a real number with no operators\"; break;\n }\n JOptionPane.showMessageDialog(null, message, \"Error \"+eCode, JOptionPane.ERROR_MESSAGE);\n return 0;\n }", "public String getErrorMessage() {\n\t\treturn errorMessage;\n\t}", "public String getErrorMessage() {\n return this.errorMessage;\n }", "public String getErrorCode();", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n java.lang.String s = ((com.google.protobuf.ByteString) ref)\n .toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "public String getErrorMessage() {\n return ERROR_MESSAGE;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (!(ref instanceof java.lang.String)) {\n com.google.protobuf.ByteString bs =\n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n } else {\n return (java.lang.String) ref;\n }\n }", "ErrorCodes(int code){\n this.code = code;\n //this.message = message;\n }", "private String formatError(String message) {\n return \"error : \" + message;\n }", "public int getError() {\n return error;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public String getErrorMessage() {\n return errorMessage;\n }", "public java.lang.String getErrorMessage() {\n java.lang.Object ref = errorMessage_;\n if (ref instanceof java.lang.String) {\n return (java.lang.String) ref;\n } else {\n com.google.protobuf.ByteString bs = \n (com.google.protobuf.ByteString) ref;\n java.lang.String s = bs.toStringUtf8();\n errorMessage_ = s;\n return s;\n }\n }", "public String getError() {\r\n\t\treturn error;\r\n\t}", "public String getParseErrorMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "java.lang.String getMessage();", "public void setErrorMsg(String text) {\n this.errorMsg = text;\n }" ]
[ "0.73851603", "0.6940896", "0.6940896", "0.69266033", "0.6780141", "0.6780141", "0.6780141", "0.67428595", "0.67137367", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.67127615", "0.65520024", "0.65114576", "0.64769644", "0.6456271", "0.642627", "0.6416267", "0.63954234", "0.6384989", "0.63848966", "0.632198", "0.62670124", "0.62642956", "0.62619805", "0.62376004", "0.62376004", "0.62376004", "0.62083954", "0.62013495", "0.6193387", "0.6147707", "0.6138214", "0.60691005", "0.6044589", "0.60406005", "0.603604", "0.5996431", "0.5991105", "0.5968466", "0.59670806", "0.5952477", "0.5923589", "0.5915698", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59148765", "0.59142876", "0.59142876", "0.59142876", "0.5912507", "0.5911042", "0.59087414", "0.59063596", "0.59046084", "0.5903917", "0.5896239", "0.5894174", "0.58929694", "0.58910334", "0.58874154", "0.5883528", "0.5878115", "0.5876815", "0.58729297", "0.58729297", "0.58729297", "0.58683634", "0.5862489", "0.586099", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.58605134", "0.5851199" ]
0.0
-1
repeated .FileInfo files = 4;
public java.util.List<entities.Torrent.FileInfo> getFilesList() { if (filesBuilder_ == null) { return java.util.Collections.unmodifiableList(files_); } else { return filesBuilder_.getMessageList(); } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.0
-1
repeated .FileInfo files = 4;
public int getFilesCount() { if (filesBuilder_ == null) { return files_.size(); } else { return filesBuilder_.getCount(); } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.0
-1
repeated .FileInfo files = 4;
public entities.Torrent.FileInfo getFiles(int index) { if (filesBuilder_ == null) { return files_.get(index); } else { return filesBuilder_.getMessage(index); } }
{ "objective": { "self": [], "paired": [], "triplet": [ [ "query", "document", "negatives" ] ] } }
[ "int getFileInfoCount();", "public void incFileCount(){\n\t\tthis.num_files++;\n\t}", "entities.Torrent.FileInfo getFiles(int index);", "public Files(){\n this.fileNameArray.add(\"bridge_1.txt\");\n this.fileNameArray.add(\"bridge_2.txt\");\n this.fileNameArray.add(\"bridge_3.txt\");\n this.fileNameArray.add(\"bridge_4.txt\");\n this.fileNameArray.add(\"bridge_5.txt\");\n this.fileNameArray.add(\"bridge_6.txt\");\n this.fileNameArray.add(\"bridge_7.txt\");\n this.fileNameArray.add(\"bridge_8.txt\");\n this.fileNameArray.add(\"bridge_9.txt\");\n this.fileNameArray.add(\"ladder_1.txt\");\n this.fileNameArray.add(\"ladder_2.txt\");\n this.fileNameArray.add(\"ladder_3.txt\");\n this.fileNameArray.add(\"ladder_4.txt\");\n this.fileNameArray.add(\"ladder_5.txt\");\n this.fileNameArray.add(\"ladder_6.txt\");\n this.fileNameArray.add(\"ladder_7.txt\");\n this.fileNameArray.add(\"ladder_8.txt\");\n this.fileNameArray.add(\"ladder_9.txt\");\n }", "int getFileNamesCount();", "int getFileNamesCount();", "ds.hdfs.generated.FileMetadata getFiles(int index);", "int getFilesCount();", "int getFilesCount();", "int getFileCount();", "private void gatherFile(FileStatus[] fstat)\r\n\t{\r\n\t inputSize = 0;\t\r\n\t paths = new Path[fstat.length];\t\r\n\t for(int i=0;i<fstat.length;i++)\r\n\t {\r\n\t inputSize+=fstat[i].getLen();\r\n\t paths[i] = fstat[i].getPath();\r\n\t }\r\n\t }", "@java.lang.Override\n public int getFileInfoCount() {\n return fileInfo_.size();\n }", "private void getExtractWithFiles(){\n\t\ttry{\n\t\t\t\n\t\t\tFileInputStream fStream = new FileInputStream(tfile);\n\t\t\tfileBytes = new byte[(int)tfile.length()];\n\t\t\t\n\t\t\tfStream.read(fileBytes, 0, fileBytes.length);\n\t\t\tfileSize = fileBytes.length;\n\t\t}catch(Exception ex){\n\t\t\tSystem.err.println(\"File Packet \"+ex.getMessage());\n\t\t}\n\t}", "public boolean nextFileInfo(FileInfo info) {\n\n\t\t// Get the next file from the search\n\n\t\ttry {\n\n\t\t\t// Return the next file details or loop until a match is found if a\n\t\t\t// complex wildcard filter\n\t\t\t// has been specified\n\t\t\twhile (m_rs.next()) {\n\t\t\t\tString name = m_rs.getString(\"name\");\n\t\t\t\t// Get the file name for the next file\n\t\t\t\tinfo.setFileId(m_rs.getInt(\"id\"));\n\t\t\t\tinfo.setFileName(name);\n\t\t\t\tinfo.setSize(m_rs.getLong(\"size\"));\n\t\t\t\tif(name.equalsIgnoreCase(DBUtil.CLOUDURL))\n\t\t\t\t{\n\t\t\t\t\ttry{\n\t\t\t\t\t//重设置大小\n\t\t\t\t\tinfo.setFileId(-99);\n//\t\t\t\t\tinfo.setFileId(-userId);\n\t\t\t\t\tinfo.setSize(DBUtil.getURLMYFILE_TXT(this.getBaseUrl(),userId).getBytes().length);\n\t\t\t\t\t}catch(Exception e)\n\t\t\t\t\t{\n\t\t\t\t\t}\n\t\t\t\t}\n\t\t\t\tlong modifyDate = m_rs.getLong(\"lastModified\");\n\t\t\t\tif (modifyDate != 0L)\n\t\t\t\t\tinfo.setModifyDateTime(modifyDate);\n\t\t\t\telse\n\t\t\t\t\tinfo.setModifyDateTime(System.currentTimeMillis());\n\t\t\t\t\n\t\t\t\tTimestamp ts = m_rs.getTimestamp(\"add_time\");\n\t\t\t\tif (ts !=null && ts.getTime()>0)\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(ts.getTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\n\t\t\t\telse\n\t\t\t\t{\n\t\t\t\t\tinfo.setCreationDateTime(info.getModifyDateTime());\n\t\t\t\t\tinfo.setChangeDateTime(info.getModifyDateTime());\n\t\t\t\t}\t\t\t\t\n\t\t\t\tint attr = 0;\n\t\t\t\tif (m_rs.getBoolean(\"isFile\") == true) {\n\t\t\t\t\tinfo.setFileType(FileType.RegularFile);\t\t\t\t\t\n\t\t\t\t\tattr += FileAttribute.ReadOnly;// 只读权限\n\t\t\t\t} else\n\t\t\t\t\tattr += FileAttribute.Directory;\n\n\t\t\t\tif (m_rs.getBoolean(\"isHidden\") == true) \n\t\t\t\t{\n\t\t\t\t\tattr += FileAttribute.Hidden;//隐藏\n\t\t\t\t}\n\t\t\t\tinfo.setFileType(FileType.Directory);\n\t\t\t\t\t\t\t\t\n\t\t\t\tif (hasMarkAsOffline()) {\n\t\t\t\t\tif (getOfflineFileSize() == 0 || info.getSize() >= getOfflineFileSize())\n\t\t\t\t\t\tattr += FileAttribute.NTOffline;\n\t\t\t\t}\n\t\t\t\tinfo.setFileAttributes(attr);\n\t\t\t\tinfo.setUid(userId);\n\n\t\t\t\tif (m_filter == null || m_filter.matchesPattern(info.getFileName()) == true)\n\t\t\t\t\treturn true;\n\t\t\t}\n\t\t} catch (SQLException ex) {\n\t\t\tex.printStackTrace();\n\t\t}\n\t\t// No more files\n\t\tcloseSearch();\n\t\treturn false;\n\t}", "private void initializeFileArrays(){\n File downloadedFilesFolder = new File(MainActivity.DB_PATH);\n File[] files = downloadedFilesFolder.listFiles();\n System.out.println(\"*** \" + files.length + \" ***\");\n if(files != null){\n System.out.println(\"*** \" + files.length + \" ***\");\n for(File f : files){\n if(f != null){\n System.out.println(\"***\\n FILE FOUND - \" + f.getAbsolutePath()+\"\\nSIZE - \" +\n f.length() + \" BYTES \\n***\");\n fileNames.add(f.getName());\n fileSizes.add(f.length()+\"\");\n this.files.add(f);\n }\n }\n }\n }", "entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index);", "List<UploadInfo> simpleUploadAll(List<SimpleFile> files);", "public List<FileUpload> getFileUploads(int numberOfFileUploads, Long startIndex) throws AppException;", "void addFile(int numberLines);", "private void updateFiles() {\n\t}", "@Override\n public void addSingleFile(FileInfo file) {\n }", "entities.Torrent.FileInfo getFileInfo(int index);", "public ImageFiles() {\n\t\tthis.listOne = new ArrayList<String>();\n\t\tthis.listTwo = new ArrayList<String>();\n\t\tthis.listThree = new ArrayList<String>();\n\t\tthis.seenImages = new ArrayList<String>();\n\t\tthis.unseenImages = new ArrayList<String>();\n\t}", "private static void showFiles(File[] files) {\n\t\t for (File file : files) {\r\n\t\t if (file.isDirectory()) {\r\n\t\t // System.out.println(\"Directory: \" + file.getName());\r\n\t\t showFiles(file.listFiles()); // Calls same method again.\r\n\t\t } else {\r\n\t\t // System.out.println(\"File: \" + file.getName());\r\n\t\t }\r\n\t\t }\r\n\t\t\r\n\t}", "public Vector<file> count()\n {\n Vector<Model.file> files = new Vector<>();\n try\n {\n pw.println(11);\n\n files = (Vector<Model.file>) ois.readObject();\n\n }\n catch (ClassNotFoundException | IOException e)\n {\n System.out.println(e.getMessage());\n }\n return files ;\n }", "private void findRecordings(){\n File[] files = new File(\"Concatenated/\").listFiles();\n _records.clear();\n _versionNum = 1;\n for (File file : files){\n if (file.isFile()){\n String nameOnFile = file.getName().substring(file.getName().lastIndexOf('_')+1,file.getName().lastIndexOf('.')).toUpperCase();\n if (nameOnFile.equals(_name.toUpperCase())){\n _records.add(file.getName());\n _versionNum++;\n }\n }\n }\n }", "private void checkDuplicateOfFile(Iterable<FileInfo> files, DuplicateDataDTO data) {\n for(FileInfo nextFile: files) {\n for(FileInfo nextFile2: files) {\n if(nextFile.duplicate(nextFile2)) {\n LOG.info(\"Duplicate - {}\", nextFile);\n\n processDuplicate(nextFile,data);\n }\n }\n }\n }", "public TagFileInfo[] getTagFiles() {\n/* 176 */ return this.tagFiles;\n/* */ }", "@Test\n\tpublic void testNumLargeFiles() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(6,Explorer.numLargeFiles(test));\n\t}", "public double getNumFiles(){\n\t\treturn (this.num_files);\n\t}", "public Files files();", "int attrib(int i, File v) {\n if (i < max) {\n AllFiles[i] = v;\n } else {\n File[] temp = new File[max];\n int j;\n for (j = 0; j < max; j++) temp[j] = AllFiles[j];\n AllFiles = new File[max + increase];\n for (j = 0; j < max; j++) AllFiles[j] = temp[j];\n max = max + increase;\n AllFiles[i] = v;\n }\n return (0);\n }", "@Test\n\tpublic void testSetFileInfo() {\n\n\t}", "public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n if (filesBuilder_ == null) {\n return files_.get(index); } else {\n return filesBuilder_.getMessageOrBuilder(index);\n }\n }", "private void readFileList() throws IOException {\n\t\tint entries = metadataFile.readInt();\n\n\t\tfor (int i = 0; i < entries; i++) {\n\t\t\tint hash = metadataFile.readInt();\n\t\t\tlong dataOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tlong dataSize = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathListIndex = metadataFile.readInt();\n\n\t\t\tlong position = metadataFile.getPosition();\n\t\t\tmetadataFile.setPosition(pathListOffset + 8 + (pathListIndex * 8));\n\n\t\t\tlong pathOffset = metadataFile.readInt() & 0xFFFFFFFFL;\n\t\t\tint pathSize = metadataFile.readInt();\n\n\t\t\tmetadataFile.setPosition(pathListOffset + pathOffset);\n\t\t\tString path = metadataFile.readString(pathSize).trim();\n\n\t\t\tif (hash == hash(path)) \n\t\t\t\tfileEntries.add(new RAFFileEntry(dataOffset, dataSize, path));\n\t\t\telse\n\t\t\t\tthrow new IOException(\"Invalid hash for item '\" + path + \"'.\");\n\n\t\t\tmetadataFile.setPosition(position);\n\t\t}\n\t}", "public Builder addAllFileInfo(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (fileInfoBuilder_ == null) {\n ensureFileInfoIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, fileInfo_);\n onChanged();\n } else {\n fileInfoBuilder_.addAllMessages(values);\n }\n return this;\n }", "public static void main(String[] args) {\n\t\tint count=0;\n\t\t File f=new File(\"C:\\\\Users\\\\kumaujjv\\\\Downloads\\\\Assignments - Copy\");\n\t\t String[] s=f.list();\n\n\t\t for(String s1:s) {\n\t\t File f1=new File(f,s1);\n\t\t if(f1.isFile()) {\n\t\t\t //count++;\n\t\t\t System.out.println(s1);\n\t\t }\n\t\t}\n\t\tSystem.out.println(\"total number : \"+count);\n\n\t\t}", "public float[] accumulateDetailFiles(ArrayList<File> files){\r\n\t\tfloat[] values = new float[100];\r\n\t\tint counter = 0;\r\n\r\n\t for(File file:files){\t\t\r\n\t \tSystem.out.println(file.getName());\r\n\t \tcounter = 0;\r\n\t BufferedReader reader;\r\n\t try{\r\n\t reader = new BufferedReader(new FileReader(file));\r\n\t String line = reader.readLine(); \r\n\t while(line != null){\t\r\n\t \tif(!line.substring(0,1).equals(\"#\")){\r\n\t \t\tString[] values2 = line.split(\" \");\r\n\t \t\tvalues[counter] += Float.valueOf(values2[values2.length-1]);\r\n\t\t \tcounter++;\r\n\t \t}\r\n\t \tline = reader.readLine();\r\n\t }\r\n\t \r\n\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t} catch (IOException e) {\r\n\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t}\r\n\t }\r\n\r\n\t float[] returnValues = new float[counter];\r\n\t \r\n\t for(int j = 0; j < returnValues.length; j++) \treturnValues[j] = ((float)values[j]/files.size());\r\n\t\r\n\t \r\n \treturn returnValues;\r\n\t}", "ds.hdfs.generated.FileMetadataOrBuilder getFilesOrBuilder(\n int index);", "private static void calculateSizes() {\n for(EmailTypes type : EmailTypes.values()){\n File f = unpackedFiles.get(type);\n setSizes.put(type, Objects.requireNonNull(f.listFiles()).length);\n }\n }", "public int[] filesRemaining();", "public static void main(String[] args) {\n\t\tFile dir = new File(\"H:\");\r\n\t\tString[] filelist = dir.list();\r\n\t\tlong total = 0;\r\n\t\tlong t = 0;\r\n\t\tfor(int i=0;i<filelist.length;i++){\r\n\t\t\t File readfile = new File(\"H:\" + \"\\\\\" + filelist[i]);\r\n\t\t\t t = readFile(readfile)/1024/1024;\r\n\t\t\t System.out.println(\"name=\" + readfile.getName() + \" size:=\" + t + \"MB\");\r\n\t\t\t total += t;\r\n\t\t}\r\n\t\tSystem.out.println(\"OK,all the files is list over,the number is \" + filelist.length + \"the total size is \" + total); \r\n\t}", "@Test\n public void tagFilesShouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(fileSpecs, LABEL_NAME, opts);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "public int getFileInfoCount() {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.size();\n } else {\n return fileInfoBuilder_.getCount();\n }\n }", "private static ArrayList<File> buildFilesArray() {\n ArrayList<File> result = new ArrayList<>();\n rAddFilesToArray(workingDirectory, result);\n return result;\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFilesOrBuilder(\n int index) {\n return files_.get(index);\n }", "java.lang.String getFileNames(int index);", "java.lang.String getFileNames(int index);", "public void filesNotFound(File... f) { }", "public void filesNotFound(File... f) { }", "public static int filesWithSizes (File f)\n\t{\n\t\tif (f.isFile())\n\t\t{\n\t\t\tif (f.length()>= 10000 && f.length() <= 25000)\n\t\t\t{\n\t\t\t\treturn 1;\n\t\t\t}\n\t\t\telse\n\t\t\t{\n\t\t\t\treturn 0;\n\t\t\t}\n\t\t}\n\t\telse\n\t\t{\n\t\t\tint count = 0;\n\t\t\tfor (File file: f.listFiles())\n\t\t\t{\n\t\t\t\tcount += filesWithSizes(file);\n\t\t\t}\n\t\t\treturn count;\n\t\t}\n\t}", "public DotFileEnumerator(String filePath)\n {\n String[] tempArr = new File(filePath).list();\n\n for (String s : tempArr) {\n fileList.add(filePath + \"/\" + s);\n }\n }", "public java.lang.String[] getNewFiles(){\r\n return localNewFiles;\r\n }", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder();", "@Test\n public void shouldReturnNonEmptyTagFiles() throws Exception {\n //given\n givenInfoMessageCode();\n //when\n List<IFileSpec> tagFiles = tagDelegator.tagFiles(\n fileSpecs,\n LABEL_NAME,\n listOnly1,\n delete1);\n //then\n assertThat(tagFiles.size(), is(1));\n assertThat(tagFiles.get(0).getDepotPathString(), is(TEST_FILE_DEPOT_PATH));\n }", "@Test\n public void maxFiles() throws Throwable {\n MergeFilesOptions opts = new MergeFilesOptions();\n opts.setStream(\"//Ace/dev\");\n opts.setReverseMapping(true);\n opts.setMaxFiles(1);\n opts.setForceStreamMerge(true);\n\n List<IFileSpec> merged = client.mergeFiles(null, null, opts);\n assertEquals(\"wrong number of files\", 1, merged.size());\n\n List<IFileSpec> opened = client.openedFiles(null, null);\n assertEquals(\"files should not have been opened\", 1, opened.size());\n }", "public FileCount(int numFiles){\n this.numFiles = numFiles;\n }", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "static public ObservableList<ImageMetaInfo> getImagesInfo(File path) {\n ObservableList<ImageMetaInfo> observableList = FXCollections.observableArrayList();\n ExtFilter fileFilter = new ExtFilter();\n File[] imageFilesArray = path.listFiles(fileFilter);\n for (File file : imageFilesArray) {\n ImageMetaInfo imageMetaInfo = getImageMetaInfo(file);\n observableList.add(imageMetaInfo);\n }\n return observableList;\n }", "private void get_file_List() {\n\tString file_name=null;\r\n\tfor (int i = 0; i < listOfFiles.length; i++) \r\n\t {\r\n\t \r\n\t if (listOfFiles[i].isFile()) \r\n\t {\r\n\t\t file_name = listOfFiles[i].getName();\r\n\t if (file_name.endsWith(\".xml\") || file_name.endsWith(\".XML\"))\r\n\t {\r\n\t file_list.add(file_name) ;\r\n\t }\r\n\t }\r\n\t }\r\n\t\r\n}", "public static void getListOfAllFileVarianta2() {\n\t\tPath pathToSrc = Paths.get(\"D:\\\\TorrentsMd\");\r\n\t\ttry {\r\n\t\t\t//cu method references\r\n//\t\t\tFiles.walk(pathToSrc)\r\n//\t\t\t\t.map(Path::toFile)\r\n//\t\t\t\t.filter(File::isFile)\r\n//\t\t\t\t.map(File::getName)\r\n//\t\t\t\t.sorted()\r\n//\t\t\t\t.forEach(System.out::println);\r\n\t\t\t\r\n\t\t\t//cu lambda, dar dpdv semantic sunt identice\r\n\t\t\tFiles.walk(pathToSrc)\r\n\t\t\t\t .map(path -> path.toFile()) //trasnform fiecare Path din stream intr-un File\r\n\t\t\t\t .filter(file -> file.isFile()) //filtrez doar fisierele\r\n\t\t\t\t .map(file -> file.getName())//transform fiecare File din stream intr-un String, care e numele sau\r\n\t\t\t\t .sorted()\r\n\t\t\t\t .forEach(file -> System.out.println(file));\r\n\t\t} catch (IOException e) {\r\n\t\t\te.printStackTrace();\r\n\t\t}\r\n\t}", "@java.lang.Override\n public int getFilesCount() {\n return files_.size();\n }", "static List<File> gitAttributes(File projectDir, Iterable<File> files) {\n List<File> gitAttrFiles = new ArrayList<>();\n Set<File> visitedFolders = new HashSet<>();\n for (File file : files) {\n gitAttrAddWithParents(projectDir, file.getAbsoluteFile(), visitedFolders, gitAttrFiles);\n }\n return gitAttrFiles;\n }", "public static int getNumberOfFiles() {\n\t\treturn EXTENSIONS.length;\n\t}", "public Map<String, NewData> getSnapshotFiles (final List<String> files){\n \t\tMap<String,NewData> w = new HashMap<String,NewData>();\n \t\tList<String> l = new LinkedList<String>();\n \t\tString s=\"\";\n \t\t\n \t\tfor (String str : files){\n \t\t\tw.put(str, new NewData(str));\n \t\t\tl=this.readFile(this.getSnapshot().getRoot() + File.separatorChar +str);\n \t\t\t\n \t\t\tfor (String str2 : l)\n \t\t\t\ts=s+str2+\"\\n\";\n \t\t\t\n \t\t\tw.get(str).setFileContent(s);\n \t\t\tw.get(str).getLclock().putAll(this.getFilelist().get(str));\n \t\t}\n \t\t\t\t\n \t\treturn w;\n \t}", "entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index);", "public void getPeerFiles(){\n\t\t\n\t\tFile[] files = new File(path).listFiles();\n\t\tfor (File file : files) {\n\t\t\tfileNames.add(file.getName());\n\t\t}\n\t\tSystem.out.println(\"Number of Files Registerd to the server - \"+fileNames.size());\n\t\tSystem.out.println(\"To search for file give command: get <Filename>\");\n\t\tSystem.out.println(\"To refresh type command: refresh\");\n\t\tSystem.out.println(\"To disconnect type command: disconnect\");\n\t}", "public static void main(String[] args) {\nFile files=new File(\"C:\\\\Users\\\\k74\");\nString filenames[]=files.list();\nfor(String filename :filenames)\n\tSystem.out.println(filename);\n\t}", "public static void rankFiles(Hashtable<?, Integer> fname, int numberOfOccurrences) \r\n\t{\n\t\tArrayList<Map.Entry<?, Integer>> arrayList = new ArrayList(fname.entrySet());\r\n\r\n\t\tCollections.sort(arrayList, new Comparator<Map.Entry<?, Integer>>() \r\n\t\t{\r\n\t\t\tpublic int compare(Map.Entry<?, Integer> obj1, Map.Entry<?, Integer> obj2) \r\n\t\t\t{\r\n\t\t\t\treturn obj1.getValue().compareTo(obj2.getValue());\r\n\t\t\t}\r\n\t\t});\r\n\r\n\t\tCollections.reverse(arrayList);\r\n\r\n\t\tif (numberOfOccurrences > 0) \r\n\t\t{\r\n\t\t\tSystem.out.println(\"\\n------Top 10 search results-----\\n\");\r\n\r\n\t\t\tint my_number = 10;\r\n\t\t\tint j = 1;\r\n\t\t\twhile (arrayList.size() > j && my_number > 0) \r\n\t\t\t{\r\n\t\t\t\tSystem.out.println(\"(\" + j + \") \" + arrayList.get(j) + \" times \");\r\n\t\t\t\tj++;\r\n\t\t\t\tmy_number--;\r\n\t\t\t}\r\n\t\t} \r\n\t}", "@Override\n public List<FileInfo> getLibrarySubFiles(FileInfo fileInfo) {\n return null;\n }", "public final void mo14831s() {\n Iterator it = ((ArrayList) mo14817d()).iterator();\n while (it.hasNext()) {\n File file = (File) it.next();\n if (file.listFiles() != null) {\n m6739b(file);\n long c = m6740c(file, false);\n if (((long) this.f6567b.mo14797a()) != c) {\n try {\n new File(new File(file, String.valueOf(c)), \"stale.tmp\").createNewFile();\n } catch (IOException unused) {\n f6563c.mo14884b(6, \"Could not write staleness marker.\", new Object[0]);\n }\n }\n for (File b : file.listFiles()) {\n m6739b(b);\n }\n }\n }\n }", "@Test\n public void testGetFilesList() {\n System.out.println(\"getFilesList from existing folder with existing subfiles\");\n String entryPath = folder.toString()+fSeparator+\"Images\";\n FilesDao instance = new FilesDao();\n String[] expResult = new String[2];\n expResult[0] = \"testImg.jpg\";\n expResult[1] = \"testImg2.jpg\";\n String[] result;\n try{\n result = instance.getFilesList(entryPath);\n }catch(EntryException ex){\n result = null;\n }\n assertArrayEquals(expResult, result);\n }", "private void populateList(File[] filesList) {\n Log.i(\"mPackage\",\"FilesList: \"+filesList.length);\n for(File file : filesList) {\n //Log.i(\"mPackage\",\"Path: \"+file);\n if(file.isDirectory()) {\n populateList(file.listFiles());\n }\n else {\n MarkerModel markerModel = new MarkerModel();\n Boolean containsObj = false;\n for(File modelFile : filesList) {\n String[] extension = modelFile.getName().split(\"\\\\.\");\n if(extension[extension.length-1].equals(\"obj\")) {\n markerModel.setObj(modelFile.getPath());\n containsObj = true;\n }\n else if(extension[extension.length-1].equals(\"mtl\"))\n markerModel.setMtl(modelFile.getPath());\n else\n markerModel.addTexture(modelFile.getPath());\n }\n if(containsObj)\n models.add(markerModel);\n return;\n //models.add(file.getPath());\n //Log.i(\"mPackage\",\"Path: \"+file.getPath());\n }\n }\n }", "java.util.List<? extends ds.hdfs.generated.FileMetadataOrBuilder> \n getFilesOrBuilderList();", "public List<String> splitByCount(String fileName, int count)\n throws IOException, InterruptedException {\n\n List<String> parts = new ArrayList<String>();\n File file = new File(fileName);\n int blockSize = (int) Math.ceil(file.length() / (double) count);\n RandomAccessFile raf = new RandomAccessFile(fileName, \"r\");\n long totalLen = raf.length();\n CountDownLatch latch = new CountDownLatch(count);\n\n long startPos = 0L;\n long nextPos = 0L;\n\n for (int i = 0; i < count; i++) {\n nextPos = Long.min((long) (i + 1) * blockSize, totalLen - 1);\n raf.seek(nextPos);\n //Calculate the start position for the next file.\n do {\n raf.seek(nextPos);\n if (raf.readByte() == '\\n') {\n nextPos = nextPos + 1;\n break;\n }\n nextPos--;\n } while (true);\n long readSizeTemp = nextPos - startPos;\n int readSize = (int) readSizeTemp;\n String partFileName = fileName.replace(\"raw\", \"raw\" + (i + 1));\n new SplitRunnable(readSize, startPos, partFileName, file, latch).run();\n startPos = nextPos;\n parts.add(partFileName);\n }\n //Wait until all the files are written.\n latch.await();\n return parts;\n }", "public float[] accumulateSimpleMixFiles(ArrayList<File> files){\r\n\t\t\tfloat[] returnValue = new float[10];\r\n\t\t\tfloat[] values = new float[10];\r\n\t\t\t\r\n\t\t for(File file:files){\t\t\t\t\t\r\n\t\t BufferedReader reader;\r\n\t\t try{\r\n\t\t reader = new BufferedReader(new FileReader(file));\r\n\t\t String line = reader.readLine(); \r\n\t\t while(line != null){\t\r\n\t\t \tif(line.substring(0,5).equals(\"Total\")){\r\n\t\t \t\tString[] values2 = line.split(\" \");\r\n\t\t \t\t\r\n\t\t \t\tfor(int i = 2; i < values2.length; i++) values[i-2] += Float.valueOf(values2[i]);\r\n\t\t \t}\r\n\t\t \tline = reader.readLine();\r\n\t\t }\r\n\t\t \r\n\t\t\t\t} catch (FileNotFoundException e) {\r\n\t\t\t\t System.err.println(\"FileNotFoundException: \" + e.getMessage());\r\n\t\t\t\t} catch (IOException e) {\r\n\t\t\t\t System.err.println(\"Caught IOException: \" + e.getMessage());\r\n\t\t\t\t}\r\n\t\t }\r\n\r\n\t\t for(int j = 0; j < values.length; j++) returnValue[j] = (float)values[j]/files.size();\t\r\n\t\t \r\n\t\t return returnValue;\r\n\t\t}", "private Map<ServerFile, Integer> totalFiles(){\n\t\tMap<ServerFile, Integer> ret = new HashMap<ServerFile, Integer>();\n\t\tfor (ClientObj c : clients){\n\t\t\tfor (ServerFile f : c.getFiles()){\n\t\t\t\tif (!ret.containsKey(f))\n\t\t\t\t\tret.put(f, 1);\n\t\t\t\telse\n\t\t\t\t\tret.put(f, ret.get(f) + 1);\n\t\t\t}\n\t\t}\n\t\treturn ret;\n\t}", "int getSourceFileCount();", "public void checkForRepeats(String selectedMarket)\r\n {\r\n System.out.println(backUpPath + selectedMarket);\r\n \tFile f = new File(backUpPath + selectedMarket);\r\n \tArrayList<File> fileContents = new ArrayList<File>(Arrays.asList(f.listFiles()));\r\n \t\r\n for(int i = 0;i< scriptAds.size();i++)\r\n \t{\r\n String currentFileName;\r\n long modified;\r\n Date modifiedDate;\r\n \r\n for(int j = 0;j < fileContents.size();j++)\r\n {\r\n currentFileName = fileContents.get(j).getName();\r\n \r\n if(currentFileName.contains(\".\"))\r\n {\r\n currentFileName = currentFileName.substring(0,currentFileName.lastIndexOf(\".\"));\r\n }\r\n if(scriptAds.get(i).getAdNumber().toLowerCase().equals(currentFileName.toLowerCase()))\r\n {\r\n modified = fileContents.get(j).lastModified();\r\n modifiedDate = new Date(modified);\r\n \r\n String dateToPrint = DateFormat.getDateTimeInstance(DateFormat.SHORT, DateFormat.SHORT).format(modifiedDate);\r\n dateToPrint = dateToPrint.substring(0,dateToPrint.indexOf(\" \"));\r\n \r\n infoText.append(\"<p>CC# \" + scriptAds.get(i).getccNumber() \r\n + \" matches a backup of last modified : \" + scriptAds.get(i).getAdNumber() \r\n + \" \" + dateToPrint + \"\\nin \" + importFileName + \"</p>\");\r\n }\r\n }\r\n }\r\n }", "public void mo83570c() {\n File[] listFiles;\n File file = new File(this.f60297d);\n if (file.isDirectory() && (listFiles = file.listFiles()) != null && listFiles.length >= this.f60294a) {\n Arrays.sort(listFiles, this.f60295b);\n for (int i = 0; i < listFiles.length && listFiles.length >= this.f60294a; i++) {\n File file2 = listFiles[i];\n if (!this.f60299f.contains(file2)) {\n ArgusLogger.m85574b(String.format(C6969H.m41409d(\"G4D8AC619BE22AF20E809D047FEE1C6C47DC3D008AD3FB969E71DD05BE6EAD1D26DC3D008AD3FB969EA079D41E6A5D1D26880DD1FBB70E36CF547\"), file2.getPath()));\n mo83569b(Collections.singleton(file2));\n }\n }\n }\n }", "public File[] filesReadOnly(File... f) { return f; }", "public List<File> getFiles();", "@Test\n\tpublic void testCountItems() {\n\t\tFile test = new File(\"X:\\\\Documents\\\\PS9 Test\");\n\t\tassertEquals(13,Explorer.countItems(test));\n\t}", "void update(FileInfo fileInfo);", "private static ArrayList m5336a(File[] fileArr) {\n ArrayList arrayList = new ArrayList();\n int i = 0;\n while (i < fileArr.length) {\n if (fileArr[i].isFile() && fileArr[i].getName().length() == 10 && TextUtils.isDigitsOnly(fileArr[i].getName())) {\n arrayList.add(fileArr[i]);\n }\n i++;\n }\n return arrayList;\n }", "@Test(timeout = 4000)\n public void test23() throws Throwable {\n FileUtil fileUtil0 = new FileUtil();\n ArrayList<Object> arrayList0 = new ArrayList<Object>();\n File file0 = fileUtil0.getAccessories(\"YP=8V~@ch)3vts}p8\", arrayList0);\n assertNull(file0);\n }", "public void findDupe(int choice) {\n\n\t\tString fullName = null;\n\t\tboolean flag = true;\n\n\t\tfor (Path file : filesArray) {\n\t\t\ttry {\n\t\t\t\tfullName = getFullName(file, choice);\n\t\t\t} catch (Exception e) {\n\t\t\t\tSystem.out.println(\"problem read file: \" + file);\n\t\t\t\tflag = false;\n\t\t\t}\n\n\t\t\tif (flag) {\n\t\t\t\tmultiMap.put(fullName, file);\n\t\t\t\tCollection<Path> vals = (Collection<Path>) multiMap.get(fullName);\n\n\t\t\t\tif (vals.size() > 1) {\n\t\t\t\t\tcounter++;\n\t\t\t\t}\n\t\t\t}\n\t\t\tflag = true;\n\t\t}\n\n\t\tSet<String> keys = multiMap.keySet();\n\t\tIterator<String> items = keys.iterator();\n\n\t\twhile (items.hasNext()) {\n\t\t\tString str = (String) items.next();\n\n\t\t\t@SuppressWarnings(\"unchecked\")\n\t\t\tCollection<Path> val = (Collection<Path>) multiMap.get(str);\n\t\t\tArrayList<Path> arr = new ArrayList<>(val);\n\n\t\t\tif (arr.size() <= 1)\n\t\t\t\titems.remove();\n\n\t\t}\n\n\t}", "java.util.List<entities.Torrent.FileInfo>\n getFileInfoList();", "List<DownloadChunk> mo54445j(int i);", "void visitFile(StorageUnit unit, long off, long lim);", "public void fileInfo(String info);", "private List<FileInfoDTO> createFileInfoDTOs(MultipartFile file1, MultipartFile file2, int totalLinesFirstFile,\n\t\t\tint totalLinesSecondFile) {\n\t\tint unmatchedRecordsFirstFile = firstFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\t\tint unmatchedRecordsSecondFile = secondFileMap.getCountMap().values().stream().mapToInt(Integer::valueOf).sum();\n\n\t\tFileInfo firstFileInfo = new FileInfo();\n\t\tfirstFileInfo.setName(file1.getOriginalFilename());\n\t\tfirstFileInfo.setTotalRecords(totalLinesFirstFile);\n\t\tfirstFileInfo.setUnmatchedRecords(unmatchedRecordsFirstFile);\n\t\tfirstFileInfo.setMatchingRecords(totalLinesFirstFile - unmatchedRecordsFirstFile);\n\n\t\tFileInfo secondFileInfo = new FileInfo();\n\t\tsecondFileInfo.setName(file2.getOriginalFilename());\n\t\tsecondFileInfo.setTotalRecords(totalLinesSecondFile);\n\t\tsecondFileInfo.setUnmatchedRecords(unmatchedRecordsSecondFile);\n\t\tsecondFileInfo.setMatchingRecords(totalLinesSecondFile - unmatchedRecordsSecondFile);\n\n\t\treturn List.of(firstFileInfo, secondFileInfo).stream()\n\t\t\t\t.map(file -> DTOConverter.convertFileInfoToFileInfoDTO(file)).collect(Collectors.toList());\n\t}", "public void a(File file, List<WxAndQqScanPathInfo> list) {\n if (file != null && !this.p) {\n File[] listFiles = file.listFiles();\n if (listFiles != null) {\n int length = listFiles.length;\n int i2 = 0;\n while (i2 < length) {\n File file2 = listFiles[i2];\n if (!this.p) {\n if (file2 != null) {\n if (!file2.isDirectory()) {\n if (!\".nomedia\".equals(file2.getName()) && file2.length() >= 5 && file2 != null && file2.exists()) {\n CleanWxItemInfo cleanWxItemInfo = new CleanWxItemInfo();\n cleanWxItemInfo.setFileType(((WxAndQqScanPathInfo) list.get(0)).getType());\n cleanWxItemInfo.setFile(file2);\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(cleanWxItemInfo.getFile().lastModified()));\n cleanWxItemInfo.setFileSize(file2.length());\n switch (((WxAndQqScanPathInfo) list.get(0)).getType()) {\n case 1:\n o += cleanWxItemInfo.getFileSize();\n d.setTotalSize(d.getTotalSize() + cleanWxItemInfo.getFileSize());\n d.setTotalNum(d.getTotalNum() + 1);\n if (d.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n d.setSelectSize(d.getSelectSize() + cleanWxItemInfo.getFileSize());\n d.setSelectNum(d.getSelectNum() + 1);\n }\n cleanWxItemInfo.setDays(TimeUtil.changeTimeToDay(0));\n a(d, cleanWxItemInfo);\n break;\n case 2:\n if (!file2.getAbsolutePath().endsWith(\"_cover\") && !new File(file2.getAbsolutePath() + \"_cover\").exists()) {\n if (!\"finishActivity\".equals(this.r) && !\"bigGarbageFragment\".equals(this.r)) {\n if (e.isFinished()) {\n j.setTotalNum(j.getTotalNum() + 1);\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n a(j, cleanWxItemInfo);\n break;\n } else {\n o += cleanWxItemInfo.getFileSize();\n e.setTotalNum(e.getTotalNum() + 1);\n e.setTotalSize(e.getTotalSize() + cleanWxItemInfo.getFileSize());\n if (e.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n e.setSelectNum(e.getSelectNum() + 1);\n e.setSelectSize(e.getSelectSize() + cleanWxItemInfo.getFileSize());\n }\n a(e, cleanWxItemInfo);\n break;\n }\n }\n } else {\n j.setTotalSize(j.getTotalSize() + cleanWxItemInfo.getFileSize());\n j.setTotalNum(j.getTotalNum() + 1);\n a(j, cleanWxItemInfo);\n break;\n }\n break;\n case 3:\n o += cleanWxItemInfo.getFileSize();\n f.setTotalSize(f.getTotalSize() + cleanWxItemInfo.getFileSize());\n f.setTotalNum(f.getTotalNum() + 1);\n if (f.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n f.setSelectSize(f.getSelectSize() + cleanWxItemInfo.getFileSize());\n f.setSelectNum(f.getSelectNum() + 1);\n }\n a(f, cleanWxItemInfo);\n break;\n case 4:\n if (file2.getName().startsWith(\"snstblur_src_\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (!file2.getName().startsWith(\"snst_\")) {\n if (file2.getName().startsWith(\"snsu_\") && new File(file2.getAbsolutePath().replace(\"snsu_\", \"snsb_\")).exists()) {\n break;\n }\n } else if (!new File(file2.getAbsolutePath().replace(\"snst_\", \"snsu_\")).exists()) {\n if (new File(file2.getAbsolutePath().replace(\"snst_\", \"snsb_\")).exists()) {\n break;\n }\n } else {\n break;\n }\n o += cleanWxItemInfo.getFileSize();\n g.setTotalSize(g.getTotalSize() + cleanWxItemInfo.getFileSize());\n g.setTotalNum(g.getTotalNum() + 1);\n if (g.isChecked()) {\n cleanWxItemInfo.setChecked(true);\n g.setSelectSize(g.getSelectSize() + cleanWxItemInfo.getFileSize());\n g.setSelectNum(g.getSelectNum() + 1);\n }\n a(g, cleanWxItemInfo);\n break;\n }\n case 5:\n if (file2.getName().endsWith(\".jpg_hevc\")) {\n if (Constants.PRIVATE_LOG_CONTROLER) {\n break;\n } else {\n file2.delete();\n break;\n }\n } else {\n if (file2.getName().startsWith(\"th_\")) {\n if (!file2.getName().endsWith(\"hd\")) {\n break;\n } else {\n break;\n }\n }\n h.setTotalSize(h.getTotalSize() + cleanWxItemInfo.getFileSize());\n h.setTotalNum(h.getTotalNum() + 1);\n a(h, cleanWxItemInfo);\n break;\n }\n case 6:\n if (!file2.getAbsolutePath().contains(\"download/appbrand\")) {\n if (file2.getName().endsWith(\".jpg\")) {\n if (!new File(file2.getAbsolutePath().replace(\".jpg\", \".mp4\")).exists() && !Constants.PRIVATE_LOG_CONTROLER) {\n file2.delete();\n break;\n }\n } else {\n i.setTotalSize(i.getTotalSize() + cleanWxItemInfo.getFileSize());\n i.setTotalNum(i.getTotalNum() + 1);\n a(i, cleanWxItemInfo);\n break;\n }\n } else {\n break;\n }\n case 8:\n k.setTotalSize(k.getTotalSize() + cleanWxItemInfo.getFileSize());\n k.setTotalNum(k.getTotalNum() + 1);\n a(k, cleanWxItemInfo);\n break;\n case 9:\n if (!file2.getName().endsWith(\".mp4\")) {\n l.setTotalSize(l.getTotalSize() + cleanWxItemInfo.getFileSize());\n l.setTotalNum(l.getTotalNum() + 1);\n l.getMineList().add(cleanWxItemInfo);\n a(l, cleanWxItemInfo);\n break;\n } else {\n m.setTotalSize(m.getTotalSize() + cleanWxItemInfo.getFileSize());\n m.setTotalNum(m.getTotalNum() + 1);\n m.getMineList().add(cleanWxItemInfo);\n a(m, cleanWxItemInfo);\n break;\n }\n case 10:\n n.setTotalSize(n.getTotalSize() + cleanWxItemInfo.getFileSize());\n n.setTotalNum(n.getTotalNum() + 1);\n a(n, cleanWxItemInfo);\n break;\n }\n }\n } else {\n try {\n if (file2.listFiles() == null || file2.listFiles().length == 0) {\n FileUtils.deleteFileAndFolder(file2);\n }\n } catch (Exception e2) {\n Logger.iCatch(Logger.TAG, Logger.ZYTAG, \"CleanWxClearNewActivity---wxFileScan ---- \", e2);\n }\n a(file2, list);\n }\n }\n i2++;\n } else {\n return;\n }\n }\n }\n }\n }", "java.util.List<? extends entities.Torrent.FileInfoOrBuilder>\n getFileInfoOrBuilderList();", "public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n if (fileInfoBuilder_ == null) {\n return fileInfo_.get(index); } else {\n return fileInfoBuilder_.getMessageOrBuilder(index);\n }\n }", "public Builder addAllFiles(\n java.lang.Iterable<? extends entities.Torrent.FileInfo> values) {\n if (filesBuilder_ == null) {\n ensureFilesIsMutable();\n com.google.protobuf.AbstractMessageLite.Builder.addAll(\n values, files_);\n onChanged();\n } else {\n filesBuilder_.addAllMessages(values);\n }\n return this;\n }", "public filesMB() {\n }", "com.google.protobuf.ByteString\n getFileNamesBytes(int index);", "public int getFileNamesCount() {\n return fileNames_.size();\n }", "@java.lang.Override\n public entities.Torrent.FileInfoOrBuilder getFileInfoOrBuilder(\n int index) {\n return fileInfo_.get(index);\n }" ]
[ "0.65325207", "0.6227456", "0.6177881", "0.6116598", "0.6065684", "0.6065684", "0.590164", "0.58970237", "0.58970237", "0.5783433", "0.57750136", "0.5763771", "0.5762734", "0.57547295", "0.5746625", "0.5744839", "0.5644452", "0.563878", "0.5628507", "0.56053144", "0.5601631", "0.5583571", "0.55456394", "0.5545325", "0.5545274", "0.5519314", "0.55032945", "0.5502879", "0.5497437", "0.54956275", "0.5495291", "0.54928", "0.5474748", "0.5458041", "0.54520524", "0.54351526", "0.5411701", "0.5409407", "0.5396235", "0.5388728", "0.5378012", "0.537654", "0.53608066", "0.5359268", "0.53519815", "0.5335172", "0.5334883", "0.5334883", "0.53343636", "0.53343636", "0.5319273", "0.5309602", "0.53086674", "0.52990717", "0.52990717", "0.5284801", "0.5278754", "0.5276997", "0.5274732", "0.52718306", "0.52717876", "0.5270142", "0.5268754", "0.5264792", "0.5254606", "0.5237259", "0.52320284", "0.52265704", "0.5221797", "0.5220387", "0.5209014", "0.5206498", "0.519874", "0.51969546", "0.5187828", "0.5185607", "0.5185165", "0.518249", "0.5176273", "0.5165428", "0.51650506", "0.5165015", "0.5163598", "0.5161906", "0.51600796", "0.51514554", "0.5150045", "0.51442325", "0.5133645", "0.51309294", "0.5130048", "0.51299196", "0.5128534", "0.51266265", "0.5125555", "0.5115963", "0.51151603", "0.51146954", "0.51012677", "0.50983685", "0.5096151" ]
0.0
-1