findbugs-exclude.xml 18 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557
  1. <!--
  2. Licensed to the Apache Software Foundation (ASF) under one or more
  3. contributor license agreements. See the NOTICE file distributed with
  4. this work for additional information regarding copyright ownership.
  5. The ASF licenses this file to You under the Apache License, Version 2.0
  6. (the "License"); you may not use this file except in compliance with
  7. the License. You may obtain a copy of the License at
  8. http://www.apache.org/licenses/LICENSE-2.0
  9. Unless required by applicable law or agreed to in writing, software
  10. distributed under the License is distributed on an "AS IS" BASIS,
  11. WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  12. See the License for the specific language governing permissions and
  13. limitations under the License.
  14. -->
  15. <FindBugsFilter>
  16. <Match>
  17. <Package name="org.apache.hadoop.record.compiler.generated" />
  18. </Match>
  19. <Match>
  20. <Bug pattern="EI_EXPOSE_REP" />
  21. </Match>
  22. <Match>
  23. <Bug pattern="EI_EXPOSE_REP2" />
  24. </Match>
  25. <Match>
  26. <Bug pattern="SE_COMPARATOR_SHOULD_BE_SERIALIZABLE" />
  27. </Match>
  28. <Match>
  29. <Class name="~.*_jsp" />
  30. <Bug pattern="DLS_DEAD_LOCAL_STORE" />
  31. </Match>
  32. <Match>
  33. <Class name="~.*_jspx" />
  34. <Bug pattern="DLS_DEAD_LOCAL_STORE" />
  35. </Match>
  36. <Match>
  37. <Field name="_jspx_dependants" />
  38. <Bug pattern="UWF_UNWRITTEN_FIELD" />
  39. </Match>
  40. <!--
  41. Inconsistent synchronization for Client.Connection.out is
  42. is intentional to make a connection to be closed instantly.
  43. -->
  44. <Match>
  45. <Class name="org.apache.hadoop.ipc.Client$Connection" />
  46. <Field name="out" />
  47. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  48. </Match>
  49. <!--
  50. Ignore Cross Scripting Vulnerabilities
  51. -->
  52. <Match>
  53. <Package name="~org.apache.hadoop.mapred.*" />
  54. <Bug code="XSS" />
  55. </Match>
  56. <Match>
  57. <Class name="org.apache.hadoop.mapred.taskdetails_jsp" />
  58. <Bug code="HRS" />
  59. </Match>
  60. <Match>
  61. <Class name="org.apache.hadoop.mapred.jobdetails_jsp"/>
  62. <Bug pattern="HRS_REQUEST_PARAMETER_TO_HTTP_HEADER"/>
  63. </Match>
  64. <Match>
  65. <Class name="org.apache.hadoop.mapred.taskstats_jsp"/>
  66. <Bug pattern="HRS_REQUEST_PARAMETER_TO_HTTP_HEADER"/>
  67. </Match>
  68. <Match>
  69. <Class name="org.apache.hadoop.mapred.jobtasks_jsp"/>
  70. <Bug pattern="HRS_REQUEST_PARAMETER_TO_HTTP_HEADER"/>
  71. </Match>
  72. <!--
  73. Ignore warnings where child class has the same name as
  74. super class. Classes based on Old API shadow names from
  75. new API. Should go off after HADOOP-1.0
  76. -->
  77. <Match>
  78. <Class name="~org.apache.hadoop.mapred.*" />
  79. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_SUPERCLASS" />
  80. </Match>
  81. <Match>
  82. <Class name="~org.apache.hadoop.mapred.*" />
  83. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_INTERFACE" />
  84. </Match>
  85. <Match>
  86. <Class name="~org.apache.hadoop.mapred.lib.aggregate.*" />
  87. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_INTERFACE" />
  88. </Match>
  89. <Match>
  90. <Class name="~org.apache.hadoop.mapred.join.*" />
  91. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_INTERFACE" />
  92. </Match>
  93. <Match>
  94. <Class name="org.apache.hadoop.mapred.SequenceFileInputFilter$Filter" />
  95. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_INTERFACE" />
  96. </Match>
  97. <Match>
  98. <Class name="~org.apache.hadoop.util.*" />
  99. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_SUPERCLASS" />
  100. </Match>
  101. <Match>
  102. <Class name="~org.apache.hadoop.filecache.*" />
  103. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_SUPERCLASS" />
  104. </Match>
  105. <!--
  106. Ignore warnings for usage of System.exit. This is
  107. required and have been well thought out
  108. -->
  109. <Match>
  110. <Class name="org.apache.hadoop.mapred.Child$2" />
  111. <Method name="run" />
  112. <Bug pattern="DM_EXIT" />
  113. </Match>
  114. <Match>
  115. <Class name="org.apache.hadoop.mapred.JobTracker" />
  116. <Method name="addHostToNodeMapping" />
  117. <Bug pattern="DM_EXIT" />
  118. </Match>
  119. <Match>
  120. <Class name="org.apache.hadoop.mapred.Task" />
  121. <Or>
  122. <Method name="done" />
  123. <Method name="commit" />
  124. <Method name="statusUpdate" />
  125. </Or>
  126. <Bug pattern="DM_EXIT" />
  127. </Match>
  128. <Match>
  129. <Class name="org.apache.hadoop.mapred.JobTracker" />
  130. <Field name="clock" />
  131. <Bug pattern="ST_WRITE_TO_STATIC_FROM_INSTANCE_METHOD" />
  132. </Match>
  133. <Match>
  134. <Class name="org.apache.hadoop.mapred.Task$TaskReporter" />
  135. <Method name="run" />
  136. <Bug pattern="DM_EXIT" />
  137. </Match>
  138. <!--
  139. We need to cast objects between old and new api objects
  140. -->
  141. <Match>
  142. <Class name="org.apache.hadoop.mapred.OutputCommitter" />
  143. <Bug pattern="BC_UNCONFIRMED_CAST" />
  144. </Match>
  145. <!--
  146. We intentionally do the get name from the inner class
  147. -->
  148. <Match>
  149. <Class name="org.apache.hadoop.mapred.TaskTracker$MapEventsFetcherThread" />
  150. <Method name="run" />
  151. <Bug pattern="IA_AMBIGUOUS_INVOCATION_OF_INHERITED_OR_OUTER_METHOD" />
  152. </Match>
  153. <Match>
  154. <Class name="org.apache.hadoop.mapred.FileOutputCommitter" />
  155. <Or>
  156. <Method name="commitJob" />
  157. <Method name="recoverTask" />
  158. <Method name="isRecoverySupported" />
  159. <Method name="isCommitJobRepeatable" />
  160. </Or>
  161. <Bug pattern="NM_WRONG_PACKAGE" />
  162. </Match>
  163. <Match>
  164. <Class name="org.apache.hadoop.mapred.OutputCommitter" />
  165. <Or>
  166. <Method name="abortJob" />
  167. <Method name="commitJob" />
  168. <Method name="cleanupJob" />
  169. <Method name="recoverTask" />
  170. <Method name="isRecoverySupported" />
  171. <Method name="isCommitJobRepeatable" />
  172. </Or>
  173. <Bug pattern="NM_WRONG_PACKAGE_INTENTIONAL" />
  174. </Match>
  175. <Match>
  176. <Class name="org.apache.hadoop.mapred.TaskCompletionEvent" />
  177. <Or>
  178. <Method name="setTaskStatus" />
  179. <Method name="setTaskAttemptId" />
  180. </Or>
  181. <Bug pattern="NM_WRONG_PACKAGE" />
  182. </Match>
  183. <Match>
  184. <Class name="org.apache.hadoop.mapred.lib.db.DBInputFormat$DBRecordReader" />
  185. <Method name="next" />
  186. <Bug pattern="NM_WRONG_PACKAGE_INTENTIONAL" />
  187. </Match>
  188. <!--
  189. Ignoring this warning as resolving this would need a non-trivial change in code
  190. -->
  191. <Match>
  192. <Class name="org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorBaseDescriptor" />
  193. <Method name="configure" />
  194. <Field name="maxNumItems" />
  195. <Bug pattern="ST_WRITE_TO_STATIC_FROM_INSTANCE_METHOD" />
  196. </Match>
  197. <!--
  198. Comes from org.apache.jasper.runtime.ResourceInjector. Cannot do much.
  199. -->
  200. <Match>
  201. <Class name="org.apache.hadoop.mapred.jobqueue_005fdetails_jsp" />
  202. <Field name="_jspx_resourceInjector" />
  203. <Bug pattern="SE_BAD_FIELD" />
  204. </Match>
  205. <!--
  206. Storing textInputFormat and then passing it as a parameter. Safe to ignore.
  207. -->
  208. <Match>
  209. <Class name="org.apache.hadoop.mapred.lib.aggregate.ValueAggregatorJob" />
  210. <Method name="createValueAggregatorJob" />
  211. <Bug pattern="DLS_DEAD_STORE_OF_CLASS_LITERAL" />
  212. </Match>
  213. <!--
  214. Can remove this after the upgrade to findbugs1.3.8
  215. -->
  216. <Match>
  217. <Class name="org.apache.hadoop.mapred.lib.db.DBInputFormat" />
  218. <Method name="getSplits" />
  219. <Bug pattern="DLS_DEAD_LOCAL_STORE" />
  220. </Match>
  221. <!--
  222. org.apache.hadoop.mapred.IndexCache is thread-safe. It does not need
  223. synchronous access.
  224. -->
  225. <Match>
  226. <Class name="org.apache.hadoop.mapred.TaskTracker" />
  227. <Field name="indexCache" />
  228. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  229. </Match>
  230. <!--
  231. None of the following variables should be referenced by any thread
  232. but the collection thread in MapTask
  233. -->
  234. <Match>
  235. <Class name="org.apache.hadoop.mapred.MapTask$MapOutputBuffer" />
  236. <Field name="kvindex" />
  237. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  238. </Match>
  239. <Match>
  240. <Class name="org.apache.hadoop.mapred.MapTask$MapOutputBuffer" />
  241. <Field name="bufferRemaining" />
  242. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  243. </Match>
  244. <Match>
  245. <Class name="org.apache.hadoop.mapred.MapTask$MapOutputBuffer" />
  246. <Field name="equator" />
  247. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  248. </Match>
  249. <!-- This is spurious. -->
  250. <Match>
  251. <Class name="org.apache.hadoop.mapred.MapTask$MapOutputBuffer$SpillThread" />
  252. <Method name="run" />
  253. <Bug pattern="UL_UNRELEASED_LOCK_EXCEPTION_PATH" />
  254. </Match>
  255. <Match>
  256. <Class name="org.apache.hadoop.mapreduce.task.reduce.MergeThread" />
  257. <Field name="inputs" />
  258. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  259. </Match>
  260. <Match>
  261. <Class name="org.apache.hadoop.mapred.JobTracker" />
  262. <Method name="updateTaskTrackerStatus" />
  263. <Bug pattern="DLS_DEAD_LOCAL_STORE" />
  264. </Match>
  265. <!--
  266. This class is unlikely to get subclassed, so ignore
  267. -->
  268. <Match>
  269. <Class name="org.apache.hadoop.mapreduce.task.reduce.MergeManagerImpl" />
  270. <Bug pattern="SC_START_IN_CTOR" />
  271. </Match>
  272. <!--
  273. This class is unlikely to get subclassed, so ignore
  274. -->
  275. <Match>
  276. <Class name="org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl" />
  277. <Bug pattern="SC_START_IN_CTOR" />
  278. </Match>
  279. <!--
  280. Do not bother if equals is not implemented. We will not need it here
  281. -->
  282. <Match>
  283. <Class name="org.apache.hadoop.mapreduce.task.reduce.ShuffleSchedulerImpl$Penalty" />
  284. <Bug pattern="EQ_COMPARETO_USE_OBJECT_EQUALS" />
  285. </Match>
  286. <!--
  287. Ignore untidy code generated by Avro
  288. -->
  289. <Match>
  290. <Class name="org.apache.hadoop.mapreduce.jobhistory.JobSubmitted" />
  291. <Bug pattern="NP_NULL_INSTANCEOF" />
  292. </Match>
  293. <Match>
  294. <Class name="org.apache.hadoop.mapred.Task" />
  295. <Method name="reportFatalError" />
  296. <Bug pattern="DM_EXIT" />
  297. </Match>
  298. <!--
  299. core changes
  300. -->
  301. <Match>
  302. <Class name="~org.apache.hadoop.*" />
  303. <Bug code="MS" />
  304. </Match>
  305. <Match>
  306. <Class name="org.apache.hadoop.fs.FileSystem" />
  307. <Method name="checkPath" />
  308. <Bug pattern="ES_COMPARING_STRINGS_WITH_EQ" />
  309. </Match>
  310. <Match>
  311. <Class name="org.apache.hadoop.fs.kfs.KFSOutputStream" />
  312. <Field name="path" />
  313. <Bug pattern="URF_UNREAD_FIELD" />
  314. </Match>
  315. <Match>
  316. <Class name="org.apache.hadoop.fs.kfs.KosmosFileSystem" />
  317. <Method name="initialize" />
  318. <Bug pattern="DM_EXIT" />
  319. </Match>
  320. <Match>
  321. <Class name="org.apache.hadoop.io.Closeable" />
  322. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_INTERFACE" />
  323. </Match>
  324. <Match>
  325. <Class name="org.apache.hadoop.security.AccessControlException" />
  326. <Bug pattern="NM_SAME_SIMPLE_NAME_AS_SUPERCLASS" />
  327. </Match>
  328. <Match>
  329. <Class name="org.apache.hadoop.record.meta.Utils" />
  330. <Method name="skip" />
  331. <Bug pattern="BC_UNCONFIRMED_CAST" />
  332. </Match>
  333. <!--
  334. The compareTo method is actually a dummy method that just
  335. throws excpetions. So, no need to override equals. Ignore
  336. -->
  337. <Match>
  338. <Class name="org.apache.hadoop.record.meta.RecordTypeInfo" />
  339. <Bug pattern="EQ_COMPARETO_USE_OBJECT_EQUALS" />
  340. </Match>
  341. <Match>
  342. <Class name="org.apache.hadoop.util.ProcfsBasedProcessTree" />
  343. <Bug pattern="DMI_HARDCODED_ABSOLUTE_FILENAME" />
  344. </Match>
  345. <!--
  346. Streaming, Examples
  347. -->
  348. <Match>
  349. <Class name="org.apache.hadoop.streaming.StreamUtil$TaskId" />
  350. <Bug pattern="URF_UNREAD_FIELD" />
  351. </Match>
  352. <Match>
  353. <Class name="org.apache.hadoop.examples.DBCountPageView" />
  354. <Method name="verify" />
  355. <Bug pattern="OBL_UNSATISFIED_OBLIGATION" />
  356. </Match>
  357. <Match>
  358. <Class name="org.apache.hadoop.examples.ContextFactory" />
  359. <Method name="setAttributes" />
  360. <Bug pattern="OBL_UNSATISFIED_OBLIGATION" />
  361. </Match>
  362. <Match>
  363. <Class name="org.apache.hadoop.mapred.TaskScheduler$QueueRefresher" />
  364. <Bug pattern="SIC_INNER_SHOULD_BE_STATIC" />
  365. </Match>
  366. <Match>
  367. <Class name="org.apache.hadoop.examples.terasort.TeraInputFormat$1" />
  368. <Method name="run" />
  369. <Bug pattern="DM_EXIT" />
  370. </Match>
  371. <Match>
  372. <Class name="org.apache.hadoop.examples.terasort.TeraOutputFormat$TeraOutputCommitter"/>
  373. <Bug pattern="NM_WRONG_PACKAGE_INTENTIONAL" />
  374. </Match>
  375. <Match>
  376. <Class name="org.apache.hadoop.examples.terasort.Unsigned16" />
  377. <Method name="getHexDigit"/>
  378. <Bug pattern="ICAST_QUESTIONABLE_UNSIGNED_RIGHT_SHIFT" />
  379. </Match>
  380. <!--
  381. False positive of FindBugs complaining that initializationPoller and
  382. started were accessed through
  383. CapacitySchedulerQueueRefresher.refreshQueues without explicitly holding
  384. the lock of CapacityTaskScheduler. The lock is in fact acquired by
  385. JobTracker prior to calling QueueManager.refereshQueues - this is
  386. necessary to ensure the order of locking (TaskScheduler ->
  387. QueueManager).
  388. -->
  389. <Match>
  390. <Class name="org.apache.hadoop.mapred.CapacityTaskScheduler" />
  391. <Field name="initializationPoller" />
  392. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  393. </Match>
  394. <Match>
  395. <Class name="org.apache.hadoop.mapred.CapacityTaskScheduler" />
  396. <Field name="started" />
  397. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  398. </Match>
  399. <!-- Yarn excludes -->
  400. <Match>
  401. <Class name="org.apache.hadoop.mapreduce.v2.app.job.impl.TaskAttemptImpl" />
  402. <Method name="computeSlotMillis" />
  403. <Bug pattern="DB_DUPLICATE_BRACHES" />
  404. </Match>
  405. <Match>
  406. <Class name="org.apache.hadoop.mapreduce.v2.app.MRAppMaster$1" />
  407. <Bug pattern="DM_EXIT" />
  408. </Match>
  409. <Match>
  410. <Class name="org.apache.hadoop.mapred.LocalContainerLauncher$SubtaskRunner" />
  411. <Bug pattern="DM_EXIT" />
  412. </Match>
  413. <Match>
  414. <Class name="~org\.apache\.hadoop\.mapreduce\.v2\.app\.job\.impl\.TaskImpl.*" />
  415. <Bug pattern="BC_UNCONFIRMED_CAST" />
  416. </Match>
  417. <Match>
  418. <Class name="~org\.apache\.hadoop\.mapreduce\.v2\.app\.job\.impl\.JobImpl.*" />
  419. <Bug pattern="BC_UNCONFIRMED_CAST" />
  420. </Match>
  421. <Match>
  422. <Class name="~org\.apache\.hadoop\.mapreduce\.v2\.app\.job\.impl\.TaskAttemptImpl.*" />
  423. <Bug pattern="BC_UNCONFIRMED_CAST" />
  424. </Match>
  425. <Match>
  426. <Class name="~org\.apache\.hadoop\.mapreduce\.v2\.app\.recover\.RecoveryService" />
  427. <Bug pattern="BC_UNCONFIRMED_CAST" />
  428. </Match>
  429. <Match>
  430. <Class name="~org\.apache\.hadoop\.mapreduce\.v2\.app\.rm\.RMContainerAllocator" />
  431. <Bug pattern="BC_UNCONFIRMED_CAST" />
  432. </Match>
  433. <Match>
  434. <Class name="org.apache.hadoop.mapreduce.v2.app.job.impl.TaskAttemptImpl" />
  435. <Method name="computeSlotMillis" />
  436. <Bug pattern="DB_DUPLICATE_BRANCHES" />
  437. </Match>
  438. <Match>
  439. <Package name="org.apache.hadoop.yarn.proto" />
  440. </Match>
  441. <Match>
  442. <Package name="org.apache.hadoop.mapreduce.v2.hs.proto" />
  443. </Match>
  444. <Match>
  445. <Class name="~org\.apache\.hadoop\.mapreduce\.v2\.proto.*" />
  446. </Match>
  447. <Match>
  448. <Package name="org.apache.hadoop.mapred.proto" />
  449. </Match>
  450. <!--
  451. The below fields are accessed locally and only via methods that are synchronized.
  452. -->
  453. <Match>
  454. <Class name="org.apache.hadoop.mapreduce.v2.app.rm.RMContainerAllocator" />
  455. <Or>
  456. <Field name="mapResourceRequest" />
  457. <Field name="reduceResourceRequest" />
  458. <Field name="maxReduceRampupLimit" />
  459. <Field name="reduceSlowStart" />
  460. <Field name="reduceNodeLabelExpression" />
  461. </Or>
  462. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  463. </Match>
  464. <Match>
  465. <Class name="org.apache.hadoop.mapreduce.v2.app.local.LocalContainerAllocator" />
  466. <Or>
  467. <Field name="retryInterval" />
  468. <Field name="retrystartTime" />
  469. </Or>
  470. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  471. </Match>
  472. <Match>
  473. <Class name="org.apache.hadoop.mapreduce.v2.app.commit.CommitterEventHandler" />
  474. <Field name="commitThreadCancelTimeoutMs" />
  475. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  476. </Match>
  477. <Match>
  478. <Class name="org.apache.hadoop.mapred.ShuffleHandler" />
  479. <Field name="sslFileBufferSize" />
  480. <Bug pattern="IS2_INCONSISTENT_SYNC" />
  481. </Match>
  482. <Match>
  483. <Class name="org.apache.hadoop.mapred.ClientServiceDelegate" />
  484. <Method name="invoke" />
  485. <Bug pattern="SWL_SLEEP_WITH_LOCK_HELD" />
  486. </Match>
  487. <Match>
  488. <Class name="org.apache.hadoop.mapreduce.util.ProcessTree" />
  489. <Method name="sendSignal" />
  490. <Bug pattern="NP_GUARANTEED_DEREF_ON_EXCEPTION_PATH" />
  491. </Match>
  492. <Match>
  493. <Class name="org.apache.hadoop.mapreduce.util.ProcessTree" />
  494. <Method name="isSetsidSupported" />
  495. <Bug pattern="NP_GUARANTEED_DEREF_ON_EXCEPTION_PATH" />
  496. </Match>
  497. <Match>
  498. <Class name="org.apache.hadoop.mapreduce.util.ProcessTree" />
  499. <Method name="isSetsidSupported" />
  500. <Bug pattern="NP_NULL_ON_SOME_PATH_EXCEPTION" />
  501. </Match>
  502. <Match>
  503. <Class name="org.apache.hadoop.mapreduce.v2.hs.CachedHistoryStorage$1" />
  504. <Bug pattern="SE_BAD_FIELD_INNER_CLASS" />
  505. </Match>
  506. <!--
  507. HADOOP-17138: Suppress warnings about unchecked Nullable
  508. since the methoad catches NullPointerException then registerError.
  509. -->
  510. <Match>
  511. <Or>
  512. <Class name="org.apache.hadoop.mapred.LocatedFileStatusFetcher$ProcessInputDirCallback" />
  513. <Class name="org.apache.hadoop.mapred.LocatedFileStatusFetcher$ProcessInitialInputPathCallback" />
  514. </Or>
  515. <Method name="onSuccess" />
  516. <Bug pattern="NP_PARAMETER_MUST_BE_NONNULL_BUT_MARKED_AS_NULLABLE" />
  517. </Match>
  518. </FindBugsFilter>